2025.03.31 18:55:11.688536 [ 407 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.03.31 18:55:11.688673 [ 407 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.03.31 18:55:11.718250 [ 407 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.03.31 18:55:11.719846 [ 407 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.03.31 18:55:36.258354 [ 407 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.03.31 18:55:36.259591 [ 407 ] {} KeeperLogStore: Removing all changelogs 2025.03.31 18:55:36.261396 [ 407 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.03.31 18:55:36.270378 [ 407 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.03.31 18:55:36.270455 [ 407 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.03.31 18:55:36.321663 [ 1121 ] {} RaftInstance: Election timeout, initiate leader election 2025.03.31 18:55:36.517600 [ 407 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.03.31 18:55:36.517685 [ 407 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.03.31 18:55:37.447593 [ 407 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.03.31 18:55:48.231835 [ 411 ] {6255aa6c-7cd9-4e27-87d3-1c2c53bc9e28} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.03.31 18:55:59.577903 [ 411 ] {b07c6fdc-c1f5-4ff5-8b1e-457332aad011} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.03.31 18:56:07.945267 [ 1136 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.03.31 18:56:11.015772 [ 1375 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.03.31 18:56:11.015884 [ 1375 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.03.31 18:56:11.132390 [ 1375 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.03.31 18:56:11.133744 [ 1375 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.03.31 18:56:36.634353 [ 1375 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.03.31 18:56:36.641268 [ 1375 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.03.31 18:56:36.641330 [ 1375 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.03.31 18:56:36.692410 [ 2093 ] {} RaftInstance: Election timeout, initiate leader election 2025.03.31 18:56:39.249447 [ 1375 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.03.31 18:57:05.033006 [ 2117 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {678509ab-f9da-41ce-b948-db4dedf33276::202503_1_6_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009656d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009133f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff77dff 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x0000000020113c7f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3a3572 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a0374 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007fce5ffbdac3 18. ? @ 0x00007fce6004f850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 18:57:21.772453 [ 2116 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.03.31 18:57:21.772833 [ 2116 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.03.31 18:57:36.238721 [ 1379 ] {68d1e749-5525-43be-ab91-56261d4c989d} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 16.81 GiB (attempt to allocate chunk of 4718592 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58794) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000838065c 11. ./build_docker/./src/Columns/ColumnString.cpp:0: COW::immutable_ptr DB::ColumnString::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x000000003759f3f8 12. ./build_docker/./src/Columns/ColumnString.cpp:240: DB::ColumnString::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037578ecf 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:323: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000399e3371 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:368: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039e1ce92 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:641: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039efbfdd 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:421: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef2f4a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a399875 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb0c944 19. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7e5f69 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7e5a76 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7e4727 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 30. ? @ 0x00007fce5ffbdac3 31. ? @ 0x00007fce6004f850 2025.03.31 18:57:38.753408 [ 1379 ] {68d1e749-5525-43be-ab91-56261d4c989d} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 16.81 GiB (attempt to allocate chunk of 4718592 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000838065c 11. ./build_docker/./src/Columns/ColumnString.cpp:0: COW::immutable_ptr DB::ColumnString::indexImpl(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x000000003759f3f8 12. ./build_docker/./src/Columns/ColumnString.cpp:240: DB::ColumnString::permute(DB::PODArray, 63ul, 64ul> const&, unsigned long) const @ 0x0000000037578ecf 13. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWriterWide.cpp:323: DB::MergeTreeDataPartWriterWide::write(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x00000000399e3371 14. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:368: DB::MergedBlockOutputStream::writeWithPermutation(DB::Block const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000039e1ce92 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:641: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039efbfdd 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:421: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef2f4a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a399875 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb0c944 19. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7e5f69 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7e5a76 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7e4727 22. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 26. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 30. ? @ 0x00007fce5ffbdac3 31. ? @ 0x00007fce6004f850 2025.03.31 18:57:51.775816 [ 2116 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.03.31 18:57:51.775932 [ 2116 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.03.31 18:57:54.132653 [ 1379 ] {6ac706ea-07cb-4d0e-adca-ef0be4c624dd} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.73 GiB (attempt to allocate chunk of 1048704 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column URLRegions): (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.10457.altinitytest (altinity build)) (from [::1]:44336) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 10. ./src/Common/PODArray.h:120: DB::ColumnVector::ColumnVector(unsigned long) @ 0x00000000378f2daa 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:69: DB::ColumnVector::cloneResized(unsigned long) const @ 0x0000000037905043 12. ./src/Columns/IColumn.h:104: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x0000000032655c74 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: 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 @ 0x0000000032659760 14. ./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) @ 0x0000000039ce60a2 15. ./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>>&) @ 0x0000000039ce43e6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c92952 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cb6136 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cae873 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d29606 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf3b934 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b750 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 2025.03.31 18:57:56.640461 [ 1379 ] {6ac706ea-07cb-4d0e-adca-ef0be4c624dd} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.73 GiB (attempt to allocate chunk of 1048704 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column URLRegions): (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 9. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 10. ./src/Common/PODArray.h:120: DB::ColumnVector::ColumnVector(unsigned long) @ 0x00000000378f2daa 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:69: DB::ColumnVector::cloneResized(unsigned long) const @ 0x0000000037905043 12. ./src/Columns/IColumn.h:104: DB::(anonymous namespace)::arrayOffsetsToSizes(DB::IColumn const&) @ 0x0000000032655c74 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: 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 @ 0x0000000032659760 14. ./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) @ 0x0000000039ce60a2 15. ./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>>&) @ 0x0000000039ce43e6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c92952 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cb6136 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cae873 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d29606 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bf3b934 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b750 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 2025.03.31 18:58:36.779438 [ 2116 ] {} CgroupsMemoryUsageObserver: Exceeded hard memory limit (14.54 GiB) 2025.03.31 18:58:36.779536 [ 2116 ] {} CgroupsMemoryUsageObserver: Exceeded soft memory limit (13.77 GiB) 2025.03.31 18:59:09.221104 [ 1379 ] {7c7b4fde-b532-4afc-bf4e-caa143507c8c} executeQuery: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.35 GiB (attempt to allocate chunk of 1057024 bytes), maximum: 15.30 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45522) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 9. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff72e05 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x00000000083f2849 11. ./src/Common/PODArray.h:0: DB::ColumnString::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x000000003759ec00 12. ./src/Processors/Merges/Algorithms/MergedData.h:58: DB::MergedData::insertRow(std::vector> const&, unsigned long, unsigned long) @ 0x000000003bb4d72f 13. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:103: DB::CollapsingSortedAlgorithm::insertRows() @ 0x000000003bb46607 14. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:0: DB::CollapsingSortedAlgorithm::merge() @ 0x000000003bb49da7 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:403: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000039ef09d7 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039ef717a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:421: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef2f4a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a399875 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb0c944 20. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7e5f69 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7e5a76 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7e4727 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007fce5ffbdac3 2025.03.31 18:59:11.326079 [ 1379 ] {7c7b4fde-b532-4afc-bf4e-caa143507c8c} TCPHandler: Code: 241. DB::Exception: Memory limit (total) exceeded: would use 15.35 GiB (attempt to allocate chunk of 1057024 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 7. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 8. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 9. ./build_docker/./src/Common/Allocator.cpp:237: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ff72e05 10. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::reserveForNextSize<>() @ 0x00000000083f2849 11. ./src/Common/PODArray.h:0: DB::ColumnString::doInsertFrom(DB::IColumn const&, unsigned long) @ 0x000000003759ec00 12. ./src/Processors/Merges/Algorithms/MergedData.h:58: DB::MergedData::insertRow(std::vector> const&, unsigned long, unsigned long) @ 0x000000003bb4d72f 13. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:103: DB::CollapsingSortedAlgorithm::insertRows() @ 0x000000003bb46607 14. ./build_docker/./src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:0: DB::CollapsingSortedAlgorithm::merge() @ 0x000000003bb49da7 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:403: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000039ef09d7 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:0: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x0000000039ef717a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:421: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000039ef2f4a 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a399875 19. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb0c944 20. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7e5f69 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7e5a76 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7e4727 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007fce5ffbdac3 2025.03.31 18:59:24.524504 [ 2850 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.03.31 18:59:24.524652 [ 2850 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.03.31 18:59:24.545757 [ 2850 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.03.31 18:59:24.549571 [ 2850 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.03.31 18:59:24.550937 [ 2850 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.03.31 18:59:50.834268 [ 2850 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.03.31 18:59:50.841163 [ 2850 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.03.31 18:59:50.841222 [ 2850 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.03.31 18:59:50.892317 [ 3571 ] {} RaftInstance: Election timeout, initiate leader election 2025.03.31 18:59:53.673852 [ 2850 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.03.31 18:59:55.709319 [ 2854 ] {3a5ff7f8-d359-46e7-99db-beb07133df07} 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.10457.altinitytest (altinity build)) (from [::1]:60284) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 18:59:55.710870 [ 2854 ] {3a5ff7f8-d359-46e7-99db-beb07133df07} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:09.445677 [ 2856 ] {c649766d-a339-4e61-bd70-43ab7807d1c1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:36574) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:09.448421 [ 2856 ] {c649766d-a339-4e61-bd70-43ab7807d1c1} DynamicQueryHandler: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:10.549194 [ 3830 ] {c26fb31d-613c-4ab6-891c-cd99c142e569} 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.10457.altinitytest (altinity build)) (from [::1]:34810) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:10.551069 [ 3830 ] {c26fb31d-613c-4ab6-891c-cd99c142e569} DynamicQueryHandler: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:11.874104 [ 2856 ] {ce8225aa-00ac-405b-8370-f1d3307130f4} 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.10457.altinitytest (altinity build)) (from [::1]:35096) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:11.876019 [ 2856 ] {ce8225aa-00ac-405b-8370-f1d3307130f4} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:12.381626 [ 3831 ] {7f3c9aa3-e96c-4a97-8066-96bb71e6211e} 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.10457.altinitytest (altinity build)) (from [::1]:35132) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:12.384212 [ 3831 ] {7f3c9aa3-e96c-4a97-8066-96bb71e6211e} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:13.380687 [ 3831 ] {5b9b027f-89d8-418c-959c-4653c28f971c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35218) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:13.382663 [ 3831 ] {5b9b027f-89d8-418c-959c-4653c28f971c} DynamicQueryHandler: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:13.607064 [ 2854 ] {722371c3-f04e-4fa3-b73f-54d3fbf5acf1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=721, jobs=706). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51706) (comment: 00082_quantiles.sql) (in query: SELECT CounterID AS k, quantilesExact(0.1, 0.5, 0.9, 0.99, 0.999)(ResolutionWidth) FROM remote('127.0.0.{1,2}', 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:00:13.609650 [ 2854 ] {722371c3-f04e-4fa3-b73f-54d3fbf5acf1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=721, jobs=706). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:00:13.851686 [ 2856 ] {abb1e11c-03f5-4231-b6d0-976b9ecdf51a} 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.10457.altinitytest (altinity build)) (from [::1]:51746) (comment: 03080_analyzer_prefer_column_name_to_alias__virtual_columns.sql) (in query: SELECT any(_partition_id), any(_sample_factor), any(_partition_id) AS _partition_id, any(_sample_factor) AS _sample_factor FROM test SETTINGS prefer_column_name_to_alias = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:13.853267 [ 2856 ] {abb1e11c-03f5-4231-b6d0-976b9ecdf51a} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:14.637916 [ 3830 ] {b0943349-c69a-422c-9dad-96dd29568bb0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35232) (comment: 03080_analyzer_prefer_column_name_to_alias__virtual_columns.sql) (in query: DROP DATABASE IF EXISTS test_t4sptzhw ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:14.639273 [ 3830 ] {b0943349-c69a-422c-9dad-96dd29568bb0} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:14.989385 [ 3863 ] {68ad1af8-9e4a-44a7-b073-505cba620d86} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51730) (comment: 02494_query_cache_exception_handling.sql) (in query: -- If an exception is thrown during query execution, no entry must be created in the query cache SELECT throwIf(1) SETTINGS use_query_cache = true;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:00:14.990186 [ 3863 ] {68ad1af8-9e4a-44a7-b073-505cba620d86} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:00:15.781408 [ 3863 ] {90c90d1c-b167-4817-a749-80bff1ef784b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35556) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:00:15.783271 [ 3863 ] {90c90d1c-b167-4817-a749-80bff1ef784b} DynamicQueryHandler: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:15.915256 [ 3863 ] {a0cab4b3-3858-4431-99df-282e961c9895} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35564) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:15.916918 [ 3863 ] {a0cab4b3-3858-4431-99df-282e961c9895} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:15.998208 [ 2856 ] {36b67e8e-3181-43ec-8464-93b9aa1f5f77} executeQuery: Code: 183. DB::Exception: Unexpected expression 'x -> toString(x) AS lambda_1' in filter in WHERE. In query WITH x -> toString(x) AS lambda_1 SELECT arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, ['1', '2', '3']) WHERE lambda_2. (UNEXPECTED_EXPRESSION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51768) (comment: 03248_invalid_where.sql) (in query: WITH x -> toString(x) AS lambda_1 SELECT arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, ['1', '2', '3']) WHERE lambda_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl::type, std::type_identity>&>::type, std::type_identity::type>, String&&, std::basic_string_view>&, String&&) @ 0x000000003358a377 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:43: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000033580410 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::validateFilters(std::shared_ptr const&) @ 0x000000003357fa43 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342b428 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:00:16.000633 [ 2856 ] {36b67e8e-3181-43ec-8464-93b9aa1f5f77} TCPHandler: Code: 183. DB::Exception: Unexpected expression 'x -> toString(x) AS lambda_1' in filter in WHERE. In query WITH x -> toString(x) AS lambda_1 SELECT arrayMap(lambda_1 AS lambda_2, [1, 2, 3]), arrayMap(lambda_2, ['1', '2', '3']) WHERE lambda_2. (UNEXPECTED_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl::type, std::type_identity>&>::type, std::type_identity::type>, String&&, std::basic_string_view>&, String&&) @ 0x000000003358a377 4. ./build_docker/./src/Analyzer/ValidationUtils.cpp:43: DB::(anonymous namespace)::validateFilter(std::shared_ptr const&, std::basic_string_view>, std::shared_ptr const&) @ 0x0000000033580410 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::validateFilters(std::shared_ptr const&) @ 0x000000003357fa43 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000003342b428 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:00:16.902685 [ 2854 ] {7ec1ce5d-1292-45e6-aeb6-0e7f1a1e08dc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51806) (comment: 00162_mmap_compression_none.sql) (in query: SELECT sum(length(Title)) FROM hits_none;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:16.904566 [ 2854 ] {7ec1ce5d-1292-45e6-aeb6-0e7f1a1e08dc} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:17.067158 [ 3831 ] {7c63b3de-348a-410a-8a58-a31688019ddf} 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.10457.altinitytest (altinity build)) (from [::1]:51774) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a41313 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a41e79 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034927ec9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:17.068319 [ 3831 ] {7c63b3de-348a-410a-8a58-a31688019ddf} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000032a41313 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a41e79 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:222: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034927ec9 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:18.040293 [ 3911 ] {a4a40ec7-92f3-49fd-b820-2b3e51b687f4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51830) (comment: 02494_query_cache_key.sql) (in query: DROP DATABASE db1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:18.276795 [ 3911 ] {a4a40ec7-92f3-49fd-b820-2b3e51b687f4} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:19.489598 [ 3863 ] {c37fde0c-8909-4fe2-a68d-d3e93d2c4e89} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51914) (comment: 02494_query_cache_key.sql) (in query: DROP DATABASE db1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:19.490501 [ 3863 ] {c37fde0c-8909-4fe2-a68d-d3e93d2c4e89} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:20.189663 [ 4187 ] {afe90c89-7578-4ea9-aacb-aac8c64d2eea} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT min(WatchID) AS min_watch_id, max(WatchID), sum(WatchID), sum(toUInt128(WatchID)), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits ORDER BY min_watch_id DESC LIMIT 20. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51864) (comment: 00165_jit_aggregate_functions.sql) (in query: SELECT min(WatchID) AS min_watch_id, max(WatchID), sum(WatchID), sum(toUInt128(WatchID)), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits ORDER BY min_watch_id DESC LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:00:20.191661 [ 4187 ] {afe90c89-7578-4ea9-aacb-aac8c64d2eea} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT min(WatchID) AS min_watch_id, max(WatchID), sum(WatchID), sum(toUInt128(WatchID)), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits ORDER BY min_watch_id DESC LIMIT 20. 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:00:20.335650 [ 3831 ] {c9bfb368-22c4-48ba-9c29-ad95d71b84a7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45678) (comment: 02494_query_cache_key.sql) (in query: DROP DATABASE IF EXISTS db1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:20.336798 [ 3831 ] {c9bfb368-22c4-48ba-9c29-ad95d71b84a7} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:20.624120 [ 3911 ] {32238fde-aad2-4ad1-9e8b-c79fc2d78de2} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT count() FROM test.hits WHERE position(URL, 'metrika') != position(URL, materialize('metrika')). (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51898) (comment: 00089_position_functions_with_non_constant_arg.sql) (in query: SELECT count() FROM test.hits WHERE position(URL, 'metrika') != position(URL, materialize('metrika'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427a9c 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 29. ? @ 0x00007f038ce47ac3 30. ? @ 0x00007f038ced9850 2025.03.31 19:00:20.625462 [ 3911 ] {32238fde-aad2-4ad1-9e8b-c79fc2d78de2} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT count() FROM test.hits WHERE position(URL, 'metrika') != position(URL, materialize('metrika')). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427a9c 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 29. ? @ 0x00007f038ce47ac3 30. ? @ 0x00007f038ced9850 2025.03.31 19:00:21.147994 [ 3831 ] {1efe42fb-b79a-4697-bc72-e9aa1d3788b2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45730) (comment: 02494_query_cache_key.sql) (in query: DROP DATABASE IF EXISTS db1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:21.149101 [ 3831 ] {1efe42fb-b79a-4697-bc72-e9aa1d3788b2} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:21.253434 [ 2856 ] {0a508c1f-bf0b-4513-8309-398975666099} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=730, jobs=715). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45658) (comment: 01656_join_defaul_enum.sql) (in query: SELECT keycol, enum_col FROM table_with_enum FULL JOIN table_key USING (keycol) ORDER BY keycol;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:00:21.255487 [ 2856 ] {0a508c1f-bf0b-4513-8309-398975666099} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=730, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:00:23.013015 [ 3831 ] {c65a5dc4-4dd1-4180-bf5c-a82251331c11} 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.10457.altinitytest (altinity build)) (from [::1]:45800) (comment: 02210_append_to_dev_dull.sql) (in query: insert into table function file('/dev/null', 'JSON', 'number UInt64') select * from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae5cf59 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:23.107182 [ 3831 ] {c65a5dc4-4dd1-4180-bf5c-a82251331c11} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae5cf59 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:23.451513 [ 3911 ] {be5ae5a7-4863-41f2-b50d-64df9b2a472a} executeQuery: Code: 497. DB::Exception: user_test_02337: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM DROP FILESYSTEM CACHE ON *.*. (ACCESS_DENIED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45820) (comment: 02337_drop_filesystem_cache_access.sh) (in query: SYSTEM DROP FILESYSTEM CACHE;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d193f 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x00000000312d13f5 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000312d016a 6. ./build_docker/./src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000003128edc6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x000000003372505b 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x000000003594fe4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:23.452197 [ 3911 ] {be5ae5a7-4863-41f2-b50d-64df9b2a472a} TCPHandler: Code: 497. DB::Exception: user_test_02337: Not enough privileges. To execute this query, it's necessary to have the grant SYSTEM DROP FILESYSTEM CACHE ON *.*. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312d193f 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const::'lambda'(DB::AccessFlags, $T&&...)::operator()<>(DB::AccessFlags, $T&&...) const @ 0x00000000312d13f5 5. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessFlags) const @ 0x00000000312d016a 6. ./build_docker/./src/Access/ContextAccess.cpp:823: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&) const @ 0x000000003128edc6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&) const @ 0x000000003372505b 8. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::execute() @ 0x000000003594fe4c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:24.698199 [ 4240 ] {42f61726-3f51-4682-8a3d-62ec19e71394} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45762) (comment: 01054_cache_dictionary_overflow_cell.sql) (in query: DROP DATABASE test_01054_overflow;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:24.699196 [ 4240 ] {42f61726-3f51-4682-8a3d-62ec19e71394} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:25.824974 [ 4187 ] {7a3ed32f-6968-479f-a809-72cde0be4098} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00161_parallel_parsing_with_names.sh) (in query: /* ddl_entry=query-0000000005 */ CREATE TABLE test_5.parsing_with_names UUID '3616a2a5-d96a-416e-b3eb-b99bfae30133' (`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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:00:25.830800 [ 4187 ] {7a3ed32f-6968-479f-a809-72cde0be4098} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45842) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:00:25.832238 [ 4187 ] {7a3ed32f-6968-479f-a809-72cde0be4098} TCPHandler: Code: 57. DB::Exception: Table test_5.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:00:26.199694 [ 3830 ] {736898b1-7403-4240-b5cb-3953688d05cb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42108) (comment: 01042_system_reload_dictionary_reloads_completely.sh) (in query: DROP DATABASE IF EXISTS test_g6sgsy50 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:26.200925 [ 3830 ] {736898b1-7403-4240-b5cb-3953688d05cb} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:26.571081 [ 4240 ] {0e5e1734-ff6c-42e9-8c8f-04ba602c3f5a} executeQuery: Code: 57. DB::Exception: Table test_01054_overflow.ints already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45958) (comment: 01054_cache_dictionary_overflow_cell.sql) (in query: create table test_01054_overflow.ints (key UInt64, i8 Int8, i16 Int16, i32 Int32, i64 Int64, u8 UInt8, u16 UInt16, u32 UInt32, u64 UInt64) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:00:26.572542 [ 4240 ] {0e5e1734-ff6c-42e9-8c8f-04ba602c3f5a} TCPHandler: Code: 57. DB::Exception: Table test_01054_overflow.ints 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:00:27.837961 [ 3831 ] {620b52d3-c478-46a8-80da-105645b2f871} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46046) (comment: 01762_deltasumtimestamp_datetime64.sh) (in query: SELECT deltaSumTimestamp(1, now64());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a84f20d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:193: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002a77b143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b0923 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dbb01 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d6259 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349e86e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:00:27.840326 [ 3831 ] {620b52d3-c478-46a8-80da-105645b2f871} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a84f20d 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:193: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002a77b143 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b0923 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dbb01 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d6259 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349e86e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:00:28.535251 [ 2854 ] {677e8fd8-a3f6-4319-b2b3-0886a06c528d} 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.10457.altinitytest (altinity build)) (from [::1]:46116) (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 LEFT 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:28.539892 [ 2854 ] {677e8fd8-a3f6-4319-b2b3-0886a06c528d} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:28.983418 [ 3830 ] {a02eaf92-7d3a-459e-9d4d-4958179bee49} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42166) (comment: 03392_replication_after_zero_copy_turned_on.sql) (in query: DROP DATABASE IF EXISTS test_yj9dsded ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:28.984674 [ 3830 ] {a02eaf92-7d3a-459e-9d4d-4958179bee49} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:29.034794 [ 3831 ] {6882c42d-16ea-4e38-abfa-c504ade8b80d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42182) (comment: 03392_replication_after_zero_copy_turned_on.sql) (in query: DROP DATABASE IF EXISTS test_yj9dsded ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:29.036122 [ 3831 ] {6882c42d-16ea-4e38-abfa-c504ade8b80d} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:29.045558 [ 3863 ] {b9eb9eb0-bb34-49b2-98ec-a69bf8741bd3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42186) (comment: 03392_replication_after_zero_copy_turned_on.sql) (in query: DROP DATABASE IF EXISTS test_yj9dsded ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:29.046729 [ 3863 ] {b9eb9eb0-bb34-49b2-98ec-a69bf8741bd3} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:29.567672 [ 4734 ] {c0d5ad2d-edb6-4a75-a9fb-e7d44f2ae436} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00161_parallel_parsing_with_names.sh) (in query: /* ddl_entry=query-0000000007 */ CREATE TABLE test_5.parsing_with_names UUID '68032595-6041-49f6-b728-9835b5c949dd' (`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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:00:29.571432 [ 4734 ] {c0d5ad2d-edb6-4a75-a9fb-e7d44f2ae436} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45540) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:00:29.572765 [ 4734 ] {c0d5ad2d-edb6-4a75-a9fb-e7d44f2ae436} TCPHandler: Code: 57. DB::Exception: Table test_5.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:00:29.803691 [ 3922 ] {43f7e871-500d-4bc1-9f46-b8eae6030fec} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46100) (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_18289' 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:29.805949 [ 3922 ] {43f7e871-500d-4bc1-9f46-b8eae6030fec} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:29.889012 [ 3863 ] {97788f02-3d27-4414-bf73-a5bd19a15d46} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=730, jobs=723). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45528) (comment: 00077_log_tinylog_stripelog.sql) (in query: SELECT count(), sum(cityHash64(*)) FROM 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:00:29.891743 [ 3863 ] {97788f02-3d27-4414-bf73-a5bd19a15d46} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=730, jobs=723). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:00:30.621278 [ 3863 ] {a14c2737-720f-4e6f-8e80-94a12ea56972} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT BIT_AND([NULL], [NULL], [NULL]);) 2025.03.31 19:00:30.622876 [ 3863 ] {a14c2737-720f-4e6f-8e80-94a12ea56972} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:30.815249 [ 3863 ] {da77e318-aef0-4f24-aa3c-49b3d4fd6563} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT BIT_OR([NULL], [NULL], [NULL]);) 2025.03.31 19:00:30.816550 [ 3863 ] {da77e318-aef0-4f24-aa3c-49b3d4fd6563} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:30.848132 [ 3863 ] {dafd6fff-0055-42fb-a314-1f731c28b6f0} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT BIT_XOR([NULL], [NULL], [NULL]);) 2025.03.31 19:00:30.849379 [ 3863 ] {dafd6fff-0055-42fb-a314-1f731c28b6f0} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:30.876346 [ 3863 ] {e08006bd-8a76-4a7e-a3f5-4e99ac9ba1f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT BLAKE3([NULL], [NULL], [NULL]);) 2025.03.31 19:00:30.877647 [ 3863 ] {e08006bd-8a76-4a7e-a3f5-4e99ac9ba1f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 3, should be 1: In scope SELECT BLAKE3([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:30.922448 [ 3863 ] {9c4ffb30-ef85-4b3f-9b51-8feb23c33ee0} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT CHARACTER_LENGTH([NULL], [NULL], [NULL]);) 2025.03.31 19:00:30.923828 [ 3863 ] {9c4ffb30-ef85-4b3f-9b51-8feb23c33ee0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHARACTER_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:30.951981 [ 3863 ] {c5d27b1b-3cc1-4337-8555-b453baa7bbc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT CHAR_LENGTH([NULL], [NULL], [NULL]);) 2025.03.31 19:00:30.953378 [ 3863 ] {c5d27b1b-3cc1-4337-8555-b453baa7bbc3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT CHAR_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:30.982310 [ 3863 ] {ab8ab6dd-b4e5-4752-a863-43264ea2dcea} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT COVAR_POP([NULL], [NULL], [NULL]);) 2025.03.31 19:00:30.983825 [ 3863 ] {ab8ab6dd-b4e5-4752-a863-43264ea2dcea} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.049120 [ 3863 ] {3ea2cd57-9f9e-4fe0-9f91-617230aea579} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT COVAR_SAMP([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.050631 [ 3863 ] {3ea2cd57-9f9e-4fe0-9f91-617230aea579} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.080075 [ 3863 ] {194bcf9e-8035-44c7-bb36-e4d1fe1ee04d} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT CRC32([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.081538 [ 3863 ] {194bcf9e-8035-44c7-bb36-e4d1fe1ee04d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 3, should be 1: In scope SELECT CRC32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.108767 [ 3863 ] {c6fabaaa-c4a3-4a0d-baf6-3430ff5a5d13} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT CRC32IEEE([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.110195 [ 3863 ] {c6fabaaa-c4a3-4a0d-baf6-3430ff5a5d13} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 3, should be 1: In scope SELECT CRC32IEEE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.136785 [ 3863 ] {25e1ad97-0ac3-47fc-9450-627fd92b7969} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT CRC64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.138273 [ 3863 ] {25e1ad97-0ac3-47fc-9450-627fd92b7969} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 3, should be 1: In scope SELECT CRC64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.194409 [ 3863 ] {bc8fac71-daef-45c1-b139-2d33c87cc1f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT DATABASE([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.195862 [ 3863 ] {bc8fac71-daef-45c1-b139-2d33c87cc1f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT DATABASE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.223523 [ 3863 ] {27c2b2fa-5d48-4bdf-bc03-28e438d1aace} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT DATE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT DATE([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.224715 [ 3863 ] {27c2b2fa-5d48-4bdf-bc03-28e438d1aace} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT DATE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.253283 [ 3863 ] {6a89e6d0-d637-4d5b-89ce-16238012e60b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT DATE_DIFF([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.254710 [ 3863 ] {6a89e6d0-d637-4d5b-89ce-16238012e60b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:31.301587 [ 3863 ] {516c0ae7-9599-4346-994b-8410a84edc54} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT DATE_FORMAT([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT DATE_FORMAT([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.302918 [ 3863 ] {516c0ae7-9599-4346-994b-8410a84edc54} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT DATE_FORMAT([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:31.399414 [ 3863 ] {a2f240a1-63c4-4998-b9c2-e8e4847cd6d9} executeQuery: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT DATE_TRUNC([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT DATE_TRUNC([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.400587 [ 3863 ] {a2f240a1-63c4-4998-b9c2-e8e4847cd6d9} TCPHandler: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT DATE_TRUNC([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:31.430732 [ 3863 ] {24bb6bbb-2e98-433f-82fe-dfaf6a8ab4c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAY([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT DAY([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.431874 [ 3863 ] {24bb6bbb-2e98-433f-82fe-dfaf6a8ab4c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAY([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.432522 [ 4187 ] {a22da688-316f-400d-ad7b-854a2e4ec9df} executeQuery: Code: 44. DB::Exception: Illegal columns of arguments of function range, the function only implemented for unsigned/signed integers up to 64 bit: In scope SELECT range(toUInt256(1), 1). (ILLEGAL_COLUMN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45548) (comment: 01780_range_msan.sql) (in query: SELECT range(toUInt256(1), 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe9609a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:00:31.433474 [ 4187 ] {a22da688-316f-400d-ad7b-854a2e4ec9df} TCPHandler: Code: 44. DB::Exception: Illegal columns of arguments of function range, the function only implemented for unsigned/signed integers up to 64 bit: In scope SELECT range(toUInt256(1), 1). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe9609a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:00:31.484438 [ 3863 ] {20f1b167-0343-44b7-8332-ac991d970848} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFMONTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT DAYOFMONTH([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.485876 [ 3863 ] {20f1b167-0343-44b7-8332-ac991d970848} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFMONTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.512654 [ 3863 ] {48614fac-b58f-489f-b762-cae8958ded12} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFWEEK([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT DAYOFWEEK([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.514100 [ 3863 ] {48614fac-b58f-489f-b762-cae8958ded12} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFWEEK([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:31.523069 [ 3922 ] {bf99f44c-8fae-43f0-9c68-2921122609c1} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 33.00 MiB (attempt to allocate chunk of 1572864 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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*&&, char const*&&, String&&, long&, String&&) @ 0x0000000020096687 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094fb3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff740a4 8. ./src/Common/HashTable/FixedHashTable.h:0: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type) @ 0x0000000035cae52a 9. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:298: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x0000000035c0176a 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x0000000035bfaec2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003476f2a4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:31.530667 [ 3922 ] {bf99f44c-8fae-43f0-9c68-2921122609c1} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 33.00 MiB (attempt to allocate chunk of 1572864 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45614) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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*&&, char const*&&, String&&, long&, String&&) @ 0x0000000020096687 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094fb3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff740a4 8. ./src/Common/HashTable/FixedHashTable.h:0: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type) @ 0x0000000035cae52a 9. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:298: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x0000000035c0176a 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x0000000035bfaec2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003476f2a4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:00:31.532028 [ 3922 ] {bf99f44c-8fae-43f0-9c68-2921122609c1} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 33.00 MiB (attempt to allocate chunk of 1572864 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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*&&, char const*&&, String&&, long&, String&&) @ 0x0000000020096687 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094fb3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff740a4 8. ./src/Common/HashTable/FixedHashTable.h:0: DB::HashJoin::MapsTemplate::create(DB::HashJoin::Type) @ 0x0000000035cae52a 9. ./build_docker/./src/Interpreters/HashJoin/HashJoin.cpp:298: DB::HashJoin::dataMapInit(std::variant, DB::HashJoin::MapsTemplate, DB::HashJoin::MapsTemplate>>>&) @ 0x0000000035c0176a 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&) @ 0x0000000035bfaec2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl, std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003476f2a4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:00:31.540634 [ 3863 ] {6fec56f0-a248-48af-800c-a662e3685412} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFYEAR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT DAYOFYEAR([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.542072 [ 3863 ] {6fec56f0-a248-48af-800c-a662e3685412} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT DAYOFYEAR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.568808 [ 3863 ] {7118365f-3c71-4a7d-8b96-1bf0b97a6843} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT FORMAT_BYTES([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.570234 [ 3863 ] {7118365f-3c71-4a7d-8b96-1bf0b97a6843} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT FORMAT_BYTES([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.596790 [ 3863 ] {b8ac36bd-5c2f-4e43-960c-f9329b3763fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT FQDN([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.598250 [ 3863 ] {b8ac36bd-5c2f-4e43-960c-f9329b3763fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT FQDN([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.684919 [ 3863 ] {13e0b9ef-c2b5-4b55-bf2d-633d99efb16f} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT FROM_BASE64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.686411 [ 3863 ] {13e0b9ef-c2b5-4b55-bf2d-633d99efb16f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT FROM_BASE64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.717527 [ 3863 ] {f7e1b781-671a-4198-bbd7-cf86298c42fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT FROM_DAYS([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.719008 [ 3863 ] {f7e1b781-671a-4198-bbd7-cf86298c42fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT FROM_DAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.755142 [ 3863 ] {a3715610-904e-4f43-9eaf-640c9e1f7a8f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT FROM_UNIXTIME([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT FROM_UNIXTIME([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.756429 [ 3863 ] {a3715610-904e-4f43-9eaf-640c9e1f7a8f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT FROM_UNIXTIME([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:31.784077 [ 3863 ] {328ccdb1-6aa6-49ba-98f6-e5001574e0fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT HOUR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT HOUR([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.785293 [ 3863 ] {328ccdb1-6aa6-49ba-98f6-e5001574e0fe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT HOUR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.814443 [ 3863 ] {f9eec5ac-63b4-41ff-99ad-d1080e7d8db7} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT INET6_ATON([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.815707 [ 3863 ] {f9eec5ac-63b4-41ff-99ad-d1080e7d8db7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET6_ATON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.915244 [ 3863 ] {92cfec23-6605-452a-a83b-e76c7b10d60b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT INET6_NTOA([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.916543 [ 3863 ] {92cfec23-6605-452a-a83b-e76c7b10d60b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT INET6_NTOA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.945279 [ 3863 ] {585591a6-8bf0-470b-9fe9-6e5517c2674f} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT INET_ATON([NULL], [NULL], [NULL]);) 2025.03.31 19:00:31.946623 [ 3863 ] {585591a6-8bf0-470b-9fe9-6e5517c2674f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT INET_ATON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:31.973223 [ 3863 ] {1d55dd70-303b-45dc-aea6-0618cce356f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT INET_NTOA([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.042603 [ 3863 ] {1d55dd70-303b-45dc-aea6-0618cce356f7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT INET_NTOA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.149257 [ 3863 ] {33cf9b3f-cf4b-445a-bd53-e63581889db6} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv4CIDRToRange([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.150598 [ 3863 ] {33cf9b3f-cf4b-445a-bd53-e63581889db6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv4CIDRToRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.179140 [ 3863 ] {974f0f5a-97bb-4717-8fd2-1dd16ff3fe96} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv4NumToString([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.180434 [ 3863 ] {974f0f5a-97bb-4717-8fd2-1dd16ff3fe96} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.211316 [ 3863 ] {b8c3a7b3-b2c6-4a1f-bf3e-26e7332ae537} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv4NumToStringClassC([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.212752 [ 3863 ] {b8c3a7b3-b2c6-4a1f-bf3e-26e7332ae537} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 3, should be 1: In scope SELECT IPv4NumToStringClassC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.242661 [ 3863 ] {7c879303-8159-4f79-91d2-7e57d38d41c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv4StringToNum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.243955 [ 3863 ] {7c879303-8159-4f79-91d2-7e57d38d41c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.271491 [ 3863 ] {e012334f-3067-47fe-bf97-f529ff2e5bc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv4StringToNumOrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.272867 [ 3863 ] {e012334f-3067-47fe-bf97-f529ff2e5bc2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.300009 [ 3863 ] {b50a78cd-58e3-41bc-a947-f16c9f68942e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv4StringToNumOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.301289 [ 3863 ] {b50a78cd-58e3-41bc-a947-f16c9f68942e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv4StringToNumOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.328200 [ 3863 ] {bc852bec-1051-41b7-88fa-a3e1ed674408} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv4ToIPv6([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.329496 [ 3863 ] {bc852bec-1051-41b7-88fa-a3e1ed674408} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 3, should be 1: In scope SELECT IPv4ToIPv6([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.356301 [ 3863 ] {23e7d28b-e2f7-4b1a-b4e4-e96865fc7915} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv6CIDRToRange([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.358342 [ 3863 ] {23e7d28b-e2f7-4b1a-b4e4-e96865fc7915} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 3, should be 2: In scope SELECT IPv6CIDRToRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.388432 [ 3863 ] {0143eb3f-3844-4ddb-bca5-b449ce1fdbcb} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv6NumToString([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.390117 [ 3863 ] {0143eb3f-3844-4ddb-bca5-b449ce1fdbcb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 3, should be 1: In scope SELECT IPv6NumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.418483 [ 3863 ] {18d14aac-ef55-48ed-9c30-4a87d570364d} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv6StringToNum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.419801 [ 3863 ] {18d14aac-ef55-48ed-9c30-4a87d570364d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.448816 [ 3863 ] {f30061b4-cd2a-424e-b49b-b51526459459} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv6StringToNumOrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.450280 [ 3863 ] {f30061b4-cd2a-424e-b49b-b51526459459} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.478159 [ 3863 ] {793569ed-1c47-4233-bfd5-423726ce16f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT IPv6StringToNumOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.479376 [ 3863 ] {793569ed-1c47-4233-bfd5-423726ce16f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 3, should be 1: In scope SELECT IPv6StringToNumOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.508600 [ 3863 ] {a8e13e00-8d8e-48a3-88ff-c5e3f279b474} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONAllPaths([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.509900 [ 3863 ] {a8e13e00-8d8e-48a3-88ff-c5e3f279b474} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 3, should be 1: In scope SELECT JSONAllPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.606582 [ 3863 ] {e3c6e211-5a71-4aca-9a7f-19d46a2db813} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONAllPathsWithTypes([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.608000 [ 3863 ] {e3c6e211-5a71-4aca-9a7f-19d46a2db813} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONAllPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.635807 [ 3863 ] {4bedf5cc-ee8f-4efe-8fad-7ade85706589} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONArrayLength([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.637050 [ 3863 ] {4bedf5cc-ee8f-4efe-8fad-7ade85706589} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSONArrayLength([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.664087 [ 3863 ] {cfbedb5a-b1da-4cc6-a949-1417bac9bc34} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONDynamicPaths([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.665424 [ 3863 ] {cfbedb5a-b1da-4cc6-a949-1417bac9bc34} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.774955 [ 3863 ] {d3580e42-5db5-4500-9270-67db035e2e3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONDynamicPathsWithTypes([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.776128 [ 3863 ] {d3580e42-5db5-4500-9270-67db035e2e3e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONDynamicPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:32.808273 [ 3863 ] {1b3aa07a-639c-4dc1-8209-5c0233b83930} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: [NULL]: In scope SELECT JSONExtract([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONExtract([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.809603 [ 3863 ] {1b3aa07a-639c-4dc1-8209-5c0233b83930} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: [NULL]: In scope SELECT JSONExtract([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) 2025.03.31 19:00:32.836753 [ 3863 ] {ccfab94c-6fdc-44a9-b1e5-5ee6a504014d} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractArrayRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONExtractArrayRaw([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.838070 [ 3863 ] {ccfab94c-6fdc-44a9-b1e5-5ee6a504014d} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractArrayRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:32.868440 [ 3863 ] {9003214d-5b3d-4b69-8164-a7fe9f567c43} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractBool([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONExtractBool([NULL], [NULL], [NULL]);) 2025.03.31 19:00:32.869459 [ 3863 ] {9003214d-5b3d-4b69-8164-a7fe9f567c43} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractBool([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:32.988592 [ 3863 ] {f71dcd02-576b-4bba-a136-e0b24c18572d} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractFloat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONExtractFloat([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.055785 [ 3863 ] {f71dcd02-576b-4bba-a136-e0b24c18572d} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractFloat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.085629 [ 3863 ] {6e9b3635-0e60-41e8-b540-2514a8f6cc3c} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractInt([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONExtractInt([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.087051 [ 3863 ] {6e9b3635-0e60-41e8-b540-2514a8f6cc3c} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractInt([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.087836 [ 3006 ] {} void DB::StorageBuffer::backgroundFlush(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038dbe04c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1088: DB::StorageBuffer::backgroundFlush() @ 0x0000000038dcb238 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038dcf41f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 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*) @ 0x00000000319a464f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:33.113689 [ 3863 ] {c2c23457-c422-4454-bbf4-9d34293fb471} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractKeys([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONExtractKeys([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.115008 [ 3863 ] {c2c23457-c422-4454-bbf4-9d34293fb471} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractKeys([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.127448 [ 4734 ] {3c8f7086-d804-476c-b214-f04fff93a54d} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00161_parallel_parsing_with_names.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_5.parsing_with_names UUID 'e8a0be26-ffbe-42e6-ab63-5b491f0309ac' (`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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:00:33.141338 [ 3863 ] {3bde04eb-d5c7-4d3a-8b61-1285b0d2aa9a} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: [NULL]: In scope SELECT JSONExtractKeysAndValues([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONExtractKeysAndValues([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.142535 [ 3863 ] {3bde04eb-d5c7-4d3a-8b61-1285b0d2aa9a} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: [NULL]: In scope SELECT JSONExtractKeysAndValues([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) 2025.03.31 19:00:33.168238 [ 3863 ] {fe47c214-8a45-41ab-add6-01f142d73489} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractKeysAndValuesRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONExtractKeysAndValuesRaw([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.169327 [ 3863 ] {fe47c214-8a45-41ab-add6-01f142d73489} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractKeysAndValuesRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.170397 [ 4734 ] {3c8f7086-d804-476c-b214-f04fff93a54d} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45696) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:00:33.171681 [ 4734 ] {3c8f7086-d804-476c-b214-f04fff93a54d} TCPHandler: Code: 57. DB::Exception: Table test_5.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:00:33.198359 [ 3863 ] {45888102-d58d-42d6-a078-a23a45d28248} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONExtractRaw([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.199593 [ 3863 ] {45888102-d58d-42d6-a078-a23a45d28248} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractRaw([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.226799 [ 3863 ] {18dc8125-d020-4489-9d93-ac0d9f336bf9} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONExtractString([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.227836 [ 3863 ] {18dc8125-d020-4489-9d93-ac0d9f336bf9} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.275642 [ 3863 ] {44eee651-9538-4c6d-ab46-2970f77b4fe1} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractUInt([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONExtractUInt([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.276924 [ 3863 ] {44eee651-9538-4c6d-ab46-2970f77b4fe1} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONExtractUInt([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.305170 [ 3863 ] {a91b8bc5-883f-40f6-84a6-53da6742edff} executeQuery: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONHas([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONHas([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.306483 [ 3863 ] {a91b8bc5-883f-40f6-84a6-53da6742edff} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONHas([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.333413 [ 3863 ] {120c008b-45ce-4189-ba4e-f1d7202c85a4} executeQuery: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONKey([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONKey([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.353689 [ 3863 ] {120c008b-45ce-4189-ba4e-f1d7202c85a4} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONKey([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.429584 [ 3863 ] {ae4a20ef-08f8-4df3-86fe-0d4ef927d6bb} executeQuery: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONLength([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONLength([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.430992 [ 3863 ] {ae4a20ef-08f8-4df3-86fe-0d4ef927d6bb} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONLength([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.459068 [ 3863 ] {0a421851-4f3d-42f1-984d-a6b802d901e5} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONMergePatch([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.460382 [ 3863 ] {0a421851-4f3d-42f1-984d-a6b802d901e5} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.489940 [ 3863 ] {2d7730ee-c5ec-45b8-a0ac-c72461541047} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONSharedDataPaths([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.491140 [ 3863 ] {2d7730ee-c5ec-45b8-a0ac-c72461541047} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPaths([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:33.518929 [ 3863 ] {1c2b5e8a-9c92-420d-b388-d0aa8cafda71} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONSharedDataPathsWithTypes([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.520126 [ 3863 ] {1c2b5e8a-9c92-420d-b388-d0aa8cafda71} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 3, should be 1: In scope SELECT JSONSharedDataPathsWithTypes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:33.548817 [ 3863 ] {af98b5cb-54a4-4e09-8a91-29184d6c3f36} executeQuery: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONType([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSONType([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.550245 [ 3863 ] {af98b5cb-54a4-4e09-8a91-29184d6c3f36} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Array(Nullable(Nothing)): In scope SELECT JSONType([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.578835 [ 3863 ] {4f18cb57-5590-4a00-a332-eca09d9c225f} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSON_ARRAY_LENGTH([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.580094 [ 3863 ] {4f18cb57-5590-4a00-a332-eca09d9c225f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 3, should be 1: In scope SELECT JSON_ARRAY_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:33.666401 [ 3863 ] {223ec061-cb5a-45d6-894f-1040875766bf} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_EXISTS([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSON_EXISTS([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.667547 [ 3863 ] {223ec061-cb5a-45d6-894f-1040875766bf} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_EXISTS([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.703444 [ 3863 ] {3319f680-be09-4dab-bb4f-e26fcf127686} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_QUERY([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSON_QUERY([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.704787 [ 3863 ] {3319f680-be09-4dab-bb4f-e26fcf127686} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_QUERY([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.736093 [ 3863 ] {b2c992c3-1a6f-4eab-8ee6-d1b5a31461b5} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_VALUE([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT JSON_VALUE([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.737587 [ 3863 ] {b2c992c3-1a6f-4eab-8ee6-d1b5a31461b5} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nullable(Nothing)): In scope SELECT JSON_VALUE([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:33.830938 [ 3863 ] {538d0f2a-d397-467f-9983-0be8fd37f065} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT L1Distance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.832178 [ 3863 ] {538d0f2a-d397-467f-9983-0be8fd37f065} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT L1Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:33.860091 [ 3863 ] {df6febab-cf6c-46d2-b4fd-d3fda7bc69fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT L1Norm([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.861490 [ 3863 ] {df6febab-cf6c-46d2-b4fd-d3fda7bc69fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT L1Norm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:33.887874 [ 3863 ] {3043cadf-b1ac-4d5b-bc09-83ef2479e1e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT L1Normalize([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.889103 [ 3863 ] {3043cadf-b1ac-4d5b-bc09-83ef2479e1e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT L1Normalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:33.916082 [ 3863 ] {641c4bdc-3eb3-44c9-b642-92efea20c7e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT L2Distance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.917291 [ 3863 ] {641c4bdc-3eb3-44c9-b642-92efea20c7e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT L2Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:33.976948 [ 3863 ] {a115478d-bca9-46f9-80fd-4b532a6e8162} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT L2Norm([NULL], [NULL], [NULL]);) 2025.03.31 19:00:33.978301 [ 3863 ] {a115478d-bca9-46f9-80fd-4b532a6e8162} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT L2Norm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.004609 [ 3863 ] {e0f7c2b3-e202-4f01-a258-7c6902d0b0ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT L2Normalize([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.006429 [ 3863 ] {e0f7c2b3-e202-4f01-a258-7c6902d0b0ba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT L2Normalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.040509 [ 3863 ] {97c1b584-eae8-4d85-b3d9-95abb4ef0eaf} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT L2SquaredDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.041541 [ 3863 ] {97c1b584-eae8-4d85-b3d9-95abb4ef0eaf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT L2SquaredDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.067076 [ 3863 ] {f49e9a9d-ad50-48f1-8a31-e066aed1178a} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT L2SquaredNorm([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.068200 [ 3863 ] {f49e9a9d-ad50-48f1-8a31-e066aed1178a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT L2SquaredNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.094078 [ 3863 ] {b8294114-cc23-44f6-8673-6c77c46ec922} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT LAST_DAY([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT LAST_DAY([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.095283 [ 3863 ] {b8294114-cc23-44f6-8673-6c77c46ec922} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT LAST_DAY([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.124299 [ 3863 ] {49c843b7-0599-4204-ae85-48afe30f9625} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT LinfDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.125598 [ 3863 ] {49c843b7-0599-4204-ae85-48afe30f9625} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT LinfDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.149985 [ 3863 ] {f629fe9e-03bf-43c8-b702-96507622004d} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT LinfNorm([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.151008 [ 3863 ] {f629fe9e-03bf-43c8-b702-96507622004d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT LinfNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.177576 [ 3863 ] {459f6937-5894-4910-8b62-e8f73ec8d5fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT LinfNormalize([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.179137 [ 3863 ] {459f6937-5894-4910-8b62-e8f73ec8d5fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT LinfNormalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.187246 [ 3830 ] {36941f31-c4b1-4548-acf9-24ab81880a73} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45684) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:00:34.188441 [ 3830 ] {36941f31-c4b1-4548-acf9-24ab81880a73} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:00:34.204023 [ 3863 ] {e8a981a9-7449-4f01-a88b-6484aa9948f4} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nullable(Nothing). Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT LpDistance([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT LpDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.205099 [ 3863 ] {e8a981a9-7449-4f01-a88b-6484aa9948f4} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nullable(Nothing). Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT LpDistance([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:34.229493 [ 3863 ] {d92125ed-a343-4df1-94f6-9e7f3f0643ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT LpNorm([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.230768 [ 3863 ] {d92125ed-a343-4df1-94f6-9e7f3f0643ba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT LpNorm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.255776 [ 3863 ] {75453881-7af1-436f-981a-13c0813bafef} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT LpNormalize([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.256939 [ 3863 ] {75453881-7af1-436f-981a-13c0813bafef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT LpNormalize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.283923 [ 3863 ] {8cda00bb-8771-42f0-ad75-18d09ab9aa88} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT MACNumToString([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.285089 [ 3863 ] {8cda00bb-8771-42f0-ad75-18d09ab9aa88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 3, should be 1: In scope SELECT MACNumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.310374 [ 3863 ] {698c1065-93a0-46cc-bf1e-002303c9725b} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT MACStringToNum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.311536 [ 3863 ] {698c1065-93a0-46cc-bf1e-002303c9725b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 3, should be 1: In scope SELECT MACStringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.337346 [ 3863 ] {11d38fa1-a6e3-4ebe-bde4-44376884c710} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT MACStringToOUI([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.338830 [ 3863 ] {11d38fa1-a6e3-4ebe-bde4-44376884c710} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 3, should be 1: In scope SELECT MACStringToOUI([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.412228 [ 3863 ] {561921af-6f54-48c9-af80-821573987861} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT MAP_FROM_ARRAYS([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.413255 [ 3863 ] {561921af-6f54-48c9-af80-821573987861} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT MAP_FROM_ARRAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.459284 [ 3863 ] {3af2fe48-9dc8-484c-96a2-76f674081c41} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT MD4([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.460623 [ 3863 ] {3af2fe48-9dc8-484c-96a2-76f674081c41} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 3, should be 1: In scope SELECT MD4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.486833 [ 3863 ] {ae2e28d7-e95f-4e3e-a170-c2a8e4821c0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT MD5([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.488072 [ 3863 ] {ae2e28d7-e95f-4e3e-a170-c2a8e4821c0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 3, should be 1: In scope SELECT MD5([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.598464 [ 3863 ] {e17647ca-66c3-4f7e-b03c-d259b1aaa581} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT MILLISECOND([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT MILLISECOND([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.599754 [ 3863 ] {e17647ca-66c3-4f7e-b03c-d259b1aaa581} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT MILLISECOND([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.630330 [ 3863 ] {5b77e17e-c7df-4817-8748-a1b9ec9f70a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT MINUTE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT MINUTE([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.631633 [ 3863 ] {5b77e17e-c7df-4817-8748-a1b9ec9f70a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT MINUTE([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.661131 [ 3863 ] {1ba2643c-f54c-446b-94cb-87aaddf49e39} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT MONTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT MONTH([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.662403 [ 3863 ] {1ba2643c-f54c-446b-94cb-87aaddf49e39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT MONTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.747281 [ 3863 ] {ae304a08-e428-4747-aa8e-95fbc1f5954c} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT OCTET_LENGTH([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.748492 [ 3863 ] {ae304a08-e428-4747-aa8e-95fbc1f5954c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT OCTET_LENGTH([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.778345 [ 3863 ] {608c4afd-45ff-41ec-99c9-7068c474deae} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT QUARTER([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT QUARTER([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.779617 [ 3863 ] {608c4afd-45ff-41ec-99c9-7068c474deae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT QUARTER([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.807212 [ 3863 ] {d95d4a98-dec0-4c45-b567-9cd0785860e7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT REGEXP_EXTRACT([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT REGEXP_EXTRACT([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.808530 [ 3863 ] {d95d4a98-dec0-4c45-b567-9cd0785860e7} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT REGEXP_EXTRACT([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:34.833873 [ 3863 ] {7f26c34b-cca5-4ba3-8cd7-b76f8b1c6f92} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT REGEXP_MATCHES([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.835100 [ 3863 ] {7f26c34b-cca5-4ba3-8cd7-b76f8b1c6f92} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT REGEXP_MATCHES([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.861036 [ 3863 ] {98727f81-3a97-4049-b1f1-2b3b7d707039} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT REGEXP_REPLACE([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT REGEXP_REPLACE([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.862456 [ 3863 ] {98727f81-3a97-4049-b1f1-2b3b7d707039} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT REGEXP_REPLACE([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:34.888176 [ 3863 ] {2f13b100-7992-4dcc-9cbc-cada4384b4a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT SCHEMA([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.889388 [ 3863 ] {2f13b100-7992-4dcc-9cbc-cada4384b4a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT SCHEMA([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:34.994913 [ 3863 ] {0a8ffe8e-0d26-421d-bc75-a629194a019e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT SECOND([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT SECOND([NULL], [NULL], [NULL]);) 2025.03.31 19:00:34.996205 [ 3863 ] {0a8ffe8e-0d26-421d-bc75-a629194a019e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT SECOND([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.023450 [ 3863 ] {9f041bf9-247f-439a-bf1c-e1e2530f5540} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT SHA1([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.024624 [ 3863 ] {9f041bf9-247f-439a-bf1c-e1e2530f5540} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 3, should be 1: In scope SELECT SHA1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.049373 [ 3863 ] {9a289fab-e995-4fd5-87f9-8f3d7aff8cb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT SHA224([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.050731 [ 3863 ] {9a289fab-e995-4fd5-87f9-8f3d7aff8cb7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 3, should be 1: In scope SELECT SHA224([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.076124 [ 3863 ] {38cbfcc9-53db-4654-997b-b4cc1e18dee1} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT SHA256([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.077370 [ 3863 ] {38cbfcc9-53db-4654-997b-b4cc1e18dee1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 3, should be 1: In scope SELECT SHA256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.101337 [ 3863 ] {ba799631-d897-43cc-82c5-ac7c5db259e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT SHA384([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.110274 [ 3863 ] {ba799631-d897-43cc-82c5-ac7c5db259e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 3, should be 1: In scope SELECT SHA384([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.136579 [ 3863 ] {cac819de-456c-4721-a0e1-eb4f3ea99a85} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT SHA512([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.137945 [ 3863 ] {cac819de-456c-4721-a0e1-eb4f3ea99a85} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 3, should be 1: In scope SELECT SHA512([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.163513 [ 3863 ] {002e94dc-d95d-4b9b-a559-8d778bc39163} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT SHA512_256([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.164817 [ 3863 ] {002e94dc-d95d-4b9b-a559-8d778bc39163} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 3, should be 1: In scope SELECT SHA512_256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.188482 [ 3863 ] {0c2713ef-337f-4856-a5ac-5aec860f2e69} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT STD([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.189465 [ 3863 ] {0c2713ef-337f-4856-a5ac-5aec860f2e69} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.212521 [ 3863 ] {0f60c475-20d0-4dce-addb-46f5e6589ed9} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT STDDEV_POP([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.213529 [ 3863 ] {0f60c475-20d0-4dce-addb-46f5e6589ed9} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.238326 [ 3863 ] {52530826-8a6b-4012-991f-bce979a5b61d} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT STDDEV_SAMP([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.239570 [ 3863 ] {52530826-8a6b-4012-991f-bce979a5b61d} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.266608 [ 3863 ] {9b7baf54-f154-4ecf-8fd0-be7f6326aa69} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndex, String expected: In scope SELECT SUBSTRING_INDEX([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT SUBSTRING_INDEX([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.267866 [ 3863 ] {9b7baf54-f154-4ecf-8fd0-be7f6326aa69} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndex, String expected: In scope SELECT SUBSTRING_INDEX([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:35.295705 [ 3863 ] {60f1bcd1-a118-49b3-ac1c-3075f3f70bb9} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT SVG([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.296691 [ 3863 ] {60f1bcd1-a118-49b3-ac1c-3075f3f70bb9} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.379073 [ 3863 ] {8acccbd4-5277-4db5-a3fc-85f5d939e7a5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT TIMESTAMP_DIFF([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.380405 [ 3863 ] {8acccbd4-5277-4db5-a3fc-85f5d939e7a5} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:35.408258 [ 3863 ] {a01f74da-209c-4cf7-b1bf-822e73f6b2f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT TO_BASE64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.409590 [ 3863 ] {a01f74da-209c-4cf7-b1bf-822e73f6b2f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT TO_BASE64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.435762 [ 3863 ] {3db03564-9cfa-4abd-b4cc-3ec00e9ebdca} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT TO_DAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT TO_DAYS([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.437024 [ 3863 ] {3db03564-9cfa-4abd-b4cc-3ec00e9ebdca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT TO_DAYS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.463940 [ 3863 ] {eb29a85e-2343-4d60-9587-02159be7ba51} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT TO_UNIXTIME([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT TO_UNIXTIME([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.465231 [ 3863 ] {eb29a85e-2343-4d60-9587-02159be7ba51} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT TO_UNIXTIME([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:35.491281 [ 3863 ] {b37699d3-8be6-4ac0-9d8a-25f0e51fcd82} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ULIDStringToDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.492580 [ 3863 ] {b37699d3-8be6-4ac0-9d8a-25f0e51fcd82} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.520694 [ 3863 ] {496a48fd-e149-4a98-9256-4386207e2948} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 3, should be 1 or 2.: In scope SELECT URLHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT URLHash([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.522163 [ 3863 ] {496a48fd-e149-4a98-9256-4386207e2948} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 3, should be 1 or 2.: In scope SELECT URLHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.551727 [ 3863 ] {3b3b215c-64dc-478d-9d8c-108fc230b8d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT URLHierarchy([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.553025 [ 3863 ] {3b3b215c-64dc-478d-9d8c-108fc230b8d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.580571 [ 3863 ] {f5fde6a1-5f8c-4d9b-a732-aa4706a62527} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT URLPathHierarchy([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.581932 [ 3863 ] {f5fde6a1-5f8c-4d9b-a732-aa4706a62527} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 3, should be 1: In scope SELECT URLPathHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.607292 [ 3863 ] {690e0f86-5455-45cf-a30b-af038d20803e} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT UTCTimestamp([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.608536 [ 3863 ] {690e0f86-5455-45cf-a30b-af038d20803e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.634274 [ 3863 ] {af6f61bd-7e6e-4986-a64c-0ae861e9538b} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT UTC_timestamp([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.635380 [ 3863 ] {af6f61bd-7e6e-4986-a64c-0ae861e9538b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 3, should be 0: In scope SELECT UTC_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.736099 [ 3863 ] {65194020-bf41-47f3-9aca-27bb3edca213} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDNumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT UUIDNumToString([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.737415 [ 3863 ] {65194020-bf41-47f3-9aca-27bb3edca213} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDNumToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.767498 [ 3863 ] {ac570ef4-520d-40a7-96a8-065a0b0fdb15} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDStringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT UUIDStringToNum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.768815 [ 3863 ] {ac570ef4-520d-40a7-96a8-065a0b0fdb15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDStringToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.796340 [ 3863 ] {a8f0d676-a0f9-4a45-b300-ffcce5686797} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT UUIDToNum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.797564 [ 3863 ] {a8f0d676-a0f9-4a45-b300-ffcce5686797} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 3, should be 1 or 2: In scope SELECT UUIDToNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.899455 [ 3863 ] {f7ffc869-7544-4bed-ac54-6d231736f8fb} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT UUIDv7ToDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.900913 [ 3863 ] {f7ffc869-7544-4bed-ac54-6d231736f8fb} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.931088 [ 3863 ] {39a54501-53b6-4ac6-bda4-d55fd053a15a} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT VAR_POP([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.932444 [ 3863 ] {39a54501-53b6-4ac6-bda4-d55fd053a15a} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:35.959304 [ 3863 ] {7fafff81-c773-4f50-b675-a9cb4291fe65} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT VAR_SAMP([NULL], [NULL], [NULL]);) 2025.03.31 19:00:35.960594 [ 3863 ] {7fafff81-c773-4f50-b675-a9cb4291fe65} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.088279 [ 3863 ] {8628e5aa-7393-46f6-bc3a-7f947d6f4300} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT YEAR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT YEAR([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.089583 [ 3863 ] {8628e5aa-7393-46f6-bc3a-7f947d6f4300} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT YEAR([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.128101 [ 3863 ] {77a3f4ac-5fd3-43cc-b5b0-77a6eab9ca03} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT YYYYMMDDToDate([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.129532 [ 3863 ] {77a3f4ac-5fd3-43cc-b5b0-77a6eab9ca03} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.157829 [ 3863 ] {4c72a300-4df4-4c79-a58d-ae41e2cbad6c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT YYYYMMDDToDate32([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.159106 [ 3863 ] {4c72a300-4df4-4c79-a58d-ae41e2cbad6c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 3 arguments: In scope SELECT YYYYMMDDToDate32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.185258 [ 3863 ] {b824c1a5-8fbd-4bfd-9a99-a5aba59d3171} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT YYYYMMDDhhmmssToDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.186865 [ 3863 ] {b824c1a5-8fbd-4bfd-9a99-a5aba59d3171} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.213360 [ 3863 ] {846590ab-03fd-44bd-b6a8-b125ce482506} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT YYYYMMDDhhmmssToDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT YYYYMMDDhhmmssToDateTime64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.214898 [ 3863 ] {846590ab-03fd-44bd-b6a8-b125ce482506} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT YYYYMMDDhhmmssToDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:36.221327 [ 4734 ] {5d351375-73bf-4113-acc3-9a5953389a1e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45876) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:36.223122 [ 4734 ] {5d351375-73bf-4113-acc3-9a5953389a1e} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:36.286515 [ 3863 ] {e86a0dde-f9b8-466e-97ed-8485c6d7fc76} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT _CAST([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.287634 [ 3863 ] {e86a0dde-f9b8-466e-97ed-8485c6d7fc76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 3, should be 2: In scope SELECT _CAST([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.314284 [ 3863 ] {6f65af7c-f4ce-4dc5-9569-5be281e03414} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT __actionName([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.315649 [ 3863 ] {6f65af7c-f4ce-4dc5-9569-5be281e03414} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 3, should be 2: In scope SELECT __actionName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.343708 [ 3863 ] {f8a39776-8359-4add-9d2d-3b841472c816} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT __bitBoolMaskAnd([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.345162 [ 3863 ] {f8a39776-8359-4add-9d2d-3b841472c816} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.371207 [ 3863 ] {6e1126b0-69f1-4c5c-bd66-f7f4d4771c73} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT __bitBoolMaskOr([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.372688 [ 3863 ] {6e1126b0-69f1-4c5c-bd66-f7f4d4771c73} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 3, should be 2: In scope SELECT __bitBoolMaskOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.399716 [ 3863 ] {fafe7f4c-999d-484a-a381-87972f8043b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT __bitSwapLastTwo([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.401191 [ 3863 ] {fafe7f4c-999d-484a-a381-87972f8043b7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 3, should be 1: In scope SELECT __bitSwapLastTwo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.568288 [ 3863 ] {15ce5c4f-2072-41b8-8a41-5b3a88a0767a} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT __bitWrapperFunc([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.569573 [ 3863 ] {15ce5c4f-2072-41b8-8a41-5b3a88a0767a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 3, should be 1: In scope SELECT __bitWrapperFunc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.595785 [ 3863 ] {d11e5032-870c-4f67-b425-ed1823eb5d12} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT __getScalar([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.597031 [ 3863 ] {d11e5032-870c-4f67-b425-ed1823eb5d12} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 3, should be 1: In scope SELECT __getScalar([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.621840 [ 3863 ] {28fb18a0-6243-479e-ac36-12de3c2f2c29} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT __scalarSubqueryResult([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.623039 [ 3863 ] {28fb18a0-6243-479e-ac36-12de3c2f2c29} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 3, should be 1: In scope SELECT __scalarSubqueryResult([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.648776 [ 3863 ] {7840fd66-1b42-403e-99db-838a54e682d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT abs([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.650119 [ 3863 ] {7840fd66-1b42-403e-99db-838a54e682d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 3, should be 1: In scope SELECT abs([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.676434 [ 3863 ] {33c32f06-db34-45b7-b13d-ece954b20cf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT accurateCast([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.678132 [ 3863 ] {33c32f06-db34-45b7-b13d-ece954b20cf1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 3, should be 2: In scope SELECT accurateCast([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.704599 [ 3863 ] {b4318cc5-61e8-44f6-82ef-3b51730acbac} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Array(Nullable(Nothing)): In scope SELECT accurateCastOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT accurateCastOrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.706094 [ 3863 ] {b4318cc5-61e8-44f6-82ef-3b51730acbac} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Array(Nullable(Nothing)): In scope SELECT accurateCastOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:36.731888 [ 3863 ] {025ef543-3b4f-4460-a4c6-77782f9853a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT accurateCastOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.733206 [ 3863 ] {025ef543-3b4f-4460-a4c6-77782f9853a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 3, should be 2: In scope SELECT accurateCastOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.830000 [ 3863 ] {23df9319-ddc1-4785-9ee3-5d253144bd56} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT acos([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.831971 [ 3863 ] {23df9319-ddc1-4785-9ee3-5d253144bd56} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 3, should be 1: In scope SELECT acos([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.861308 [ 3863 ] {a1b02ab5-b2f2-44cb-a150-c159cd0e5b0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT acosh([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.862666 [ 3863 ] {a1b02ab5-b2f2-44cb-a150-c159cd0e5b0c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 3, should be 1: In scope SELECT acosh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.894021 [ 3863 ] {de781975-1d17-4d5f-984f-1e971ef9f105} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addDate([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.895418 [ 3863 ] {de781975-1d17-4d5f-984f-1e971ef9f105} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 3, should be 2: In scope SELECT addDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:36.927004 [ 3863 ] {e8290b53-7ea6-48ed-bb9c-49cedae41c42} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addDays. Must be a DateTime/DateTime64: In scope SELECT addDays([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addDays([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.928497 [ 3863 ] {e8290b53-7ea6-48ed-bb9c-49cedae41c42} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addDays. Must be a DateTime/DateTime64: In scope SELECT addDays([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:36.954927 [ 3863 ] {cf962b95-18fa-4764-aa95-5bb1a9ad65cb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addHours. Must be a DateTime/DateTime64: In scope SELECT addHours([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addHours([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.956434 [ 3863 ] {cf962b95-18fa-4764-aa95-5bb1a9ad65cb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addHours. Must be a DateTime/DateTime64: In scope SELECT addHours([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:36.982803 [ 3863 ] {2ca8537e-9bcd-4828-8b1b-a93eea264929} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addInterval([NULL], [NULL], [NULL]);) 2025.03.31 19:00:36.984203 [ 3863 ] {2ca8537e-9bcd-4828-8b1b-a93eea264929} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 3, should be 2: In scope SELECT addInterval([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:37.011999 [ 3863 ] {cbe3100f-be29-4145-a579-1f8fd148740c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMicroseconds. Must be a DateTime/DateTime64: In scope SELECT addMicroseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addMicroseconds([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.013385 [ 3863 ] {cbe3100f-be29-4145-a579-1f8fd148740c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMicroseconds. Must be a DateTime/DateTime64: In scope SELECT addMicroseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.040722 [ 3863 ] {fac7275d-73b4-498c-a5a2-7a8f72f4cc20} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMilliseconds. Must be a DateTime/DateTime64: In scope SELECT addMilliseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addMilliseconds([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.042051 [ 3863 ] {fac7275d-73b4-498c-a5a2-7a8f72f4cc20} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMilliseconds. Must be a DateTime/DateTime64: In scope SELECT addMilliseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.070313 [ 3863 ] {e258bc03-ddc3-40aa-a7aa-253df1d119ff} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope SELECT addMinutes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addMinutes([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.071633 [ 3863 ] {e258bc03-ddc3-40aa-a7aa-253df1d119ff} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope SELECT addMinutes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.101307 [ 3863 ] {6bcb7ea4-e430-4b27-ab15-1c3408ff961a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMonths. Must be a DateTime/DateTime64: In scope SELECT addMonths([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addMonths([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.102700 [ 3863 ] {6bcb7ea4-e430-4b27-ab15-1c3408ff961a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addMonths. Must be a DateTime/DateTime64: In scope SELECT addMonths([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.137575 [ 3863 ] {abf4ceb7-ef85-4ebe-94fc-d72692822144} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addNanoseconds. Must be a DateTime/DateTime64: In scope SELECT addNanoseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addNanoseconds([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.139003 [ 3863 ] {abf4ceb7-ef85-4ebe-94fc-d72692822144} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addNanoseconds. Must be a DateTime/DateTime64: In scope SELECT addNanoseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.169100 [ 3863 ] {21f0fd17-9dcc-4a84-ac54-65815426500e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope SELECT addQuarters([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addQuarters([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.170673 [ 3863 ] {21f0fd17-9dcc-4a84-ac54-65815426500e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope SELECT addQuarters([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.200041 [ 3863 ] {88dfee95-8cd9-4943-aea9-9464f7cb4d0f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope SELECT addSeconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addSeconds([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.201467 [ 3863 ] {88dfee95-8cd9-4943-aea9-9464f7cb4d0f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope SELECT addSeconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.231829 [ 3863 ] {16e7f7c0-fae2-42cf-8d21-98a2f2061026} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addTupleOfIntervals([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.233202 [ 3863 ] {16e7f7c0-fae2-42cf-8d21-98a2f2061026} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT addTupleOfIntervals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:37.261086 [ 3863 ] {ce33d454-6380-4e65-8e32-104b1f66b772} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope SELECT addWeeks([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addWeeks([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.262651 [ 3863 ] {ce33d454-6380-4e65-8e32-104b1f66b772} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope SELECT addWeeks([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.293581 [ 3863 ] {3b2acfee-c21b-4aa9-b238-44840204163b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addYears. Must be a DateTime/DateTime64: In scope SELECT addYears([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addYears([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.296487 [ 3863 ] {3b2acfee-c21b-4aa9-b238-44840204163b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function addYears. Must be a DateTime/DateTime64: In scope SELECT addYears([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.327441 [ 3863 ] {374849ec-6836-48da-b181-b54e77017075} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addressToLine([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.328936 [ 3863 ] {374849ec-6836-48da-b181-b54e77017075} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 3, should be 1: In scope SELECT addressToLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:37.357505 [ 3863 ] {7fe5ec37-624b-4769-b8c1-a022a9a1cc14} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addressToLineWithInlines([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.440800 [ 3863 ] {7fe5ec37-624b-4769-b8c1-a022a9a1cc14} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 3, should be 1: In scope SELECT addressToLineWithInlines([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:37.472021 [ 3863 ] {7d2b3a8a-0bf6-4c6d-a289-b05469323263} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT addressToSymbol([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.473328 [ 3863 ] {7d2b3a8a-0bf6-4c6d-a289-b05469323263} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 3, should be 1: In scope SELECT addressToSymbol([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:37.505348 [ 3863 ] {4733ad81-c4a1-4b9b-9247-b59659601d05} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_decrypt_mysql'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT aes_decrypt_mysql([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT aes_decrypt_mysql([NULL], '[HIDDEN]')) 2025.03.31 19:00:37.507034 [ 3863 ] {4733ad81-c4a1-4b9b-9247-b59659601d05} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_decrypt_mysql'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT aes_decrypt_mysql([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.538957 [ 3863 ] {045522ee-2e23-4052-b4c5-1ae816fbaffb} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: Array(Nullable(Nothing)): In scope SELECT aes_encrypt_mysql([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT aes_encrypt_mysql([NULL], '[HIDDEN]')) 2025.03.31 19:00:37.540266 [ 3863 ] {045522ee-2e23-4052-b4c5-1ae816fbaffb} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'aes_encrypt_mysql'. Expected: encryption mode string, got: Array(Nullable(Nothing)): In scope SELECT aes_encrypt_mysql([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.662319 [ 3863 ] {12e01132-7966-4e40-8b86-acb83a5c2099} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'age'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT age([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT age([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.664046 [ 3863 ] {12e01132-7966-4e40-8b86-acb83a5c2099} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'age'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT age([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.705102 [ 3863 ] {a673c1ec-fce0-4f95-bf71-1df5efa9ea7e} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT aggThrow([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.707145 [ 3863 ] {a673c1ec-fce0-4f95-bf71-1df5efa9ea7e} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) 2025.03.31 19:00:37.734897 [ 3863 ] {41d750fe-34a5-4c26-a25c-45fb902c2459} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT alphaTokens([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT alphaTokens([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.736004 [ 3863 ] {41d750fe-34a5-4c26-a25c-45fb902c2459} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT alphaTokens([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:37.838410 [ 3863 ] {1484d980-9415-4099-8ece-8f0a704b711c} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT analysisOfVariance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.839716 [ 3863 ] {1484d980-9415-4099-8ece-8f0a704b711c} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:37.868457 [ 3863 ] {73472596-a903-47e0-a3fa-cbad99304dfb} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function and: In scope SELECT [NULL] AND [NULL] AND [NULL]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT and([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.869901 [ 3863 ] {73472596-a903-47e0-a3fa-cbad99304dfb} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function and: In scope SELECT [NULL] AND [NULL] AND [NULL]. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:37.896654 [ 3863 ] {0aedcc00-5e2f-4dbd-86d2-718aa9ea3c98} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT anova([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.897914 [ 3863 ] {0aedcc00-5e2f-4dbd-86d2-718aa9ea3c98} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:37.926140 [ 3863 ] {e8c68a92-8a95-4be6-b816-120e0e8be6aa} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT any([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.927423 [ 3863 ] {e8c68a92-8a95-4be6-b816-120e0e8be6aa} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:37.953909 [ 3863 ] {4c795362-22d1-4621-9e89-19596b21cf1e} executeQuery: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT anyHeavy([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.955015 [ 3863 ] {4c795362-22d1-4621-9e89-19596b21cf1e} TCPHandler: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:37.978800 [ 3863 ] {c0510ec0-97c6-4a4d-9d40-3c83186f5545} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT anyLast([NULL], [NULL], [NULL]);) 2025.03.31 19:00:37.980041 [ 3863 ] {c0510ec0-97c6-4a4d-9d40-3c83186f5545} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:37.991002 [ 4187 ] {422aaf0a-1439-484f-aed5-0ad2d29ce696} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=17). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45958) (comment: 00148_monotonic_functions_and_index.sql) (in query: SELECT count() FROM test.hits WHERE -CounterID = -1731;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:37.993757 [ 4187 ] {422aaf0a-1439-484f-aed5-0ad2d29ce696} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=17, jobs=17). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:38.004014 [ 3863 ] {dc6c62a2-e20f-4f29-a103-d44708d49b06} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT anyLast_respect_nulls([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.005164 [ 3863 ] {dc6c62a2-e20f-4f29-a103-d44708d49b06} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.030804 [ 3863 ] {11b418ac-ad03-4639-8195-38000e0ab13a} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT any_respect_nulls([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.032125 [ 3863 ] {11b418ac-ad03-4639-8195-38000e0ab13a} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.057074 [ 3863 ] {09f27507-f255-416b-8791-929d7fb999f8} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT any_value([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.058350 [ 3863 ] {09f27507-f255-416b-8791-929d7fb999f8} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.083563 [ 3863 ] {106be262-31e9-474b-a2c6-95d58e7f6e9b} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT any_value_respect_nulls([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.084916 [ 3863 ] {106be262-31e9-474b-a2c6-95d58e7f6e9b} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.143994 [ 3863 ] {37e9a916-d882-4210-beb3-c63058b0d846} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT appendTrailingCharIfAbsent([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.145312 [ 3863 ] {37e9a916-d882-4210-beb3-c63058b0d846} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 3, should be 2: In scope SELECT appendTrailingCharIfAbsent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.168960 [ 3863 ] {f52f854e-ca05-4fa3-b11a-523b1e691adf} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT approx_top_count([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.170265 [ 3863 ] {f52f854e-ca05-4fa3-b11a-523b1e691adf} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.193959 [ 3863 ] {c7e78462-6e48-4ce6-aa6f-69965dd1e9be} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT approx_top_k([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.195077 [ 3863 ] {c7e78462-6e48-4ce6-aa6f-69965dd1e9be} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.220086 [ 3863 ] {c5f1b8af-558d-4bb4-888a-69a6101dae42} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT approx_top_sum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.221268 [ 3863 ] {c5f1b8af-558d-4bb4-888a-69a6101dae42} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.246435 [ 3863 ] {83e4afd0-7a2a-4fc3-bb0a-c9712fec5dac} executeQuery: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT argMax([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.247768 [ 3863 ] {83e4afd0-7a2a-4fc3-bb0a-c9712fec5dac} TCPHandler: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.312819 [ 3863 ] {42d355bc-0442-4940-a46f-52e05ea4365b} executeQuery: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT argMin([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.314213 [ 3863 ] {42d355bc-0442-4940-a46f-52e05ea4365b} TCPHandler: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.381763 [ 3863 ] {940262d6-2c8b-4289-8c06-0c60b04b21a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUC doesn't match: passed 3, should be 2: In scope SELECT arrayAUC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayAUC([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.383164 [ 3863 ] {940262d6-2c8b-4289-8c06-0c60b04b21a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUC doesn't match: passed 3, should be 2: In scope SELECT arrayAUC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.411460 [ 3863 ] {fddc1aea-2eb6-410d-a2e5-58457ab28b85} executeQuery: Code: 43. DB::Exception: First argument for function arrayAll must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayAll([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.412935 [ 3863 ] {fddc1aea-2eb6-410d-a2e5-58457ab28b85} TCPHandler: Code: 43. DB::Exception: First argument for function arrayAll must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:38.440249 [ 3863 ] {d9443c8a-445f-4bd6-9e70-26748f4cfa72} executeQuery: Code: 43. DB::Exception: First argument for function arrayAvg must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayAvg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayAvg([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.441616 [ 3863 ] {d9443c8a-445f-4bd6-9e70-26748f4cfa72} TCPHandler: Code: 43. DB::Exception: First argument for function arrayAvg must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayAvg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:38.478161 [ 3863 ] {29f43026-be1e-45aa-a17e-5a8862591594} executeQuery: Code: 43. DB::Exception: First argument for function arrayCompact must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCompact([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayCompact([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.479376 [ 3863 ] {29f43026-be1e-45aa-a17e-5a8862591594} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCompact must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCompact([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:38.600612 [ 3863 ] {7c24568d-0d94-4953-ac22-593482de30c2} executeQuery: Code: 43. DB::Exception: First argument for function arrayCount must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCount([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayCount([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.601653 [ 3863 ] {7c24568d-0d94-4953-ac22-593482de30c2} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCount must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCount([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:38.626582 [ 3863 ] {b14dbecd-d6be-4876-a42a-cef347cd7add} executeQuery: Code: 43. DB::Exception: First argument for function arrayCumSum must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCumSum([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayCumSum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.627705 [ 3863 ] {b14dbecd-d6be-4876-a42a-cef347cd7add} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCumSum must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCumSum([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:38.654256 [ 3863 ] {68b909f4-d064-4298-9830-ce35d96055ed} executeQuery: Code: 43. DB::Exception: First argument for function arrayCumSumNonNegative must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCumSumNonNegative([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayCumSumNonNegative([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.655615 [ 3863 ] {68b909f4-d064-4298-9830-ce35d96055ed} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCumSumNonNegative must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayCumSumNonNegative([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:38.680839 [ 3863 ] {5ca05246-2e68-441f-8943-bf2b4e6597d5} executeQuery: Code: 43. DB::Exception: First argument for function arrayDifference must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayDifference([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayDifference([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.682031 [ 3863 ] {5ca05246-2e68-441f-8943-bf2b4e6597d5} TCPHandler: Code: 43. DB::Exception: First argument for function arrayDifference must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayDifference([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:38.706720 [ 3863 ] {78b8cad5-d4f8-4d15-a71c-edba9b0b098b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayDistinct([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.707783 [ 3863 ] {78b8cad5-d4f8-4d15-a71c-edba9b0b098b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 3, should be 1: In scope SELECT arrayDistinct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.734467 [ 3863 ] {f1c84f15-0277-489e-a91b-c8a5d490537d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayDotProduct([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.735834 [ 3863 ] {f1c84f15-0277-489e-a91b-c8a5d490537d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 3, should be 2: In scope SELECT arrayDotProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.762259 [ 3863 ] {d26c2739-49ef-4de7-b3a1-554bfa4a8ac1} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayElement([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.763597 [ 3863 ] {d26c2739-49ef-4de7-b3a1-554bfa4a8ac1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 3, should be 2: In scope SELECT arrayElement([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.789362 [ 3863 ] {50e91c32-72b8-4e43-89ae-d60d3cf5116c} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayEnumerate([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.790563 [ 3863 ] {50e91c32-72b8-4e43-89ae-d60d3cf5116c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 3, should be 1: In scope SELECT arrayEnumerate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:38.952917 [ 3863 ] {d0cd4577-fee7-4ad0-8582-443dd41f5c17} executeQuery: Code: 43. DB::Exception: First argument for function arrayExists must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayExists([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayExists([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.954150 [ 3863 ] {d0cd4577-fee7-4ad0-8582-443dd41f5c17} TCPHandler: Code: 43. DB::Exception: First argument for function arrayExists must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayExists([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:38.979964 [ 3863 ] {8886c143-be04-44e5-aea8-3221b05dbd6b} executeQuery: Code: 43. DB::Exception: First argument for function arrayFill must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFill([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayFill([NULL], [NULL], [NULL]);) 2025.03.31 19:00:38.981042 [ 3863 ] {8886c143-be04-44e5-aea8-3221b05dbd6b} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFill must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFill([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.012323 [ 3863 ] {6239c620-d3a3-4fca-b501-5c0389d0dd14} executeQuery: Code: 43. DB::Exception: First argument for function arrayFilter must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFilter([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayFilter([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.013595 [ 3863 ] {6239c620-d3a3-4fca-b501-5c0389d0dd14} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFilter must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFilter([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.041525 [ 3863 ] {d98a7fdd-5f9e-45cb-a84b-43e40e21a46d} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirst must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirst([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayFirst([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.043272 [ 3863 ] {d98a7fdd-5f9e-45cb-a84b-43e40e21a46d} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirst must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirst([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.069386 [ 3863 ] {37b34301-aab5-4552-8bae-716d27772be3} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirstIndex must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirstIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayFirstIndex([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.070816 [ 3863 ] {37b34301-aab5-4552-8bae-716d27772be3} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirstIndex must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirstIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.096652 [ 3863 ] {df58c5a6-8866-43e3-98bd-381c18d36bb4} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirstOrNull must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirstOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayFirstOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.098046 [ 3863 ] {df58c5a6-8866-43e3-98bd-381c18d36bb4} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirstOrNull must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayFirstOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.194962 [ 3863 ] {a265d512-79a9-4ecc-9910-b96290244d80} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayFlatten([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.196216 [ 3863 ] {a265d512-79a9-4ecc-9910-b96290244d80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT arrayFlatten([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:39.222173 [ 3863 ] {662f5a7a-658e-4ae9-83b4-45376ec2daad} executeQuery: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayFold([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.223418 [ 3863 ] {662f5a7a-658e-4ae9-83b4-45376ec2daad} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFold must be a function: In scope SELECT arrayFold([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.248975 [ 3863 ] {89962348-f313-4ba4-bc0d-910d67f1de33} executeQuery: Code: 44. DB::Exception: Nullable(Nothing) cannot be inside Nullable column: In scope SELECT arrayIntersect([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayIntersect([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.250217 [ 3863 ] {89962348-f313-4ba4-bc0d-910d67f1de33} TCPHandler: Code: 44. DB::Exception: Nullable(Nothing) cannot be inside Nullable column: In scope SELECT arrayIntersect([NULL], [NULL], [NULL]). (ILLEGAL_COLUMN) 2025.03.31 19:00:39.283896 [ 3863 ] {8c4cab0a-9a50-4917-986c-79219f5d8d71} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayJaccardIndex([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.285764 [ 3863 ] {8c4cab0a-9a50-4917-986c-79219f5d8d71} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT arrayJaccardIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:39.310742 [ 3863 ] {6d2fb1d3-9de6-4bd3-abfe-f36d3497d1da} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayJoin([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.312027 [ 3863 ] {6d2fb1d3-9de6-4bd3-abfe-f36d3497d1da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 3, should be 1: In scope SELECT arrayJoin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:39.337696 [ 3863 ] {7c03914f-c03f-404e-8b95-e15e0a841a44} executeQuery: Code: 43. DB::Exception: First argument for function arrayLast must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLast([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayLast([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.339092 [ 3863 ] {7c03914f-c03f-404e-8b95-e15e0a841a44} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLast must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLast([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.364807 [ 3863 ] {6ee119c9-ef42-4fd3-932a-ae9360c69c86} executeQuery: Code: 43. DB::Exception: First argument for function arrayLastIndex must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLastIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayLastIndex([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.366305 [ 3863 ] {6ee119c9-ef42-4fd3-932a-ae9360c69c86} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLastIndex must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLastIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.454583 [ 3863 ] {548a740c-fe7b-4689-bc69-18c9e2326985} executeQuery: Code: 43. DB::Exception: First argument for function arrayLastOrNull must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLastOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayLastOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.455891 [ 3863 ] {548a740c-fe7b-4689-bc69-18c9e2326985} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLastOrNull must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayLastOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.484135 [ 3863 ] {dc670c11-150d-47fc-8a79-86e66af2115f} executeQuery: Code: 43. DB::Exception: First argument for function arrayMap must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMap([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayMap([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.485500 [ 3863 ] {dc670c11-150d-47fc-8a79-86e66af2115f} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMap must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMap([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.515327 [ 3863 ] {e2e85a36-94b7-4d55-aeb1-3390ca836b19} executeQuery: Code: 43. DB::Exception: First argument for function arrayMax must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayMax([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.516517 [ 3863 ] {e2e85a36-94b7-4d55-aeb1-3390ca836b19} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMax must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.541808 [ 3863 ] {f01c7c75-c4a0-442d-83c7-22d5f15e901b} executeQuery: Code: 43. DB::Exception: First argument for function arrayMin must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMin([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayMin([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.542864 [ 3863 ] {f01c7c75-c4a0-442d-83c7-22d5f15e901b} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMin must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayMin([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.572474 [ 3863 ] {5adc7d36-356b-48fd-8cfb-350fcbdd551d} executeQuery: Code: 43. DB::Exception: First argument for function arrayPartialReverseSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayPartialReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayPartialReverseSort([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.573653 [ 3863 ] {5adc7d36-356b-48fd-8cfb-350fcbdd551d} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPartialReverseSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayPartialReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.599643 [ 3863 ] {0d0c244c-7810-4ba3-9b39-d06e33395612} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of arguments of function arrayPartialShuffle (must be UInt or Int): In scope SELECT arrayPartialShuffle([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayPartialShuffle([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.601029 [ 3863 ] {0d0c244c-7810-4ba3-9b39-d06e33395612} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of arguments of function arrayPartialShuffle (must be UInt or Int): In scope SELECT arrayPartialShuffle([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.626486 [ 3863 ] {5f3434c8-1c12-46a0-bd8d-df80ec71216b} executeQuery: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayPartialSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayPartialSort([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.627639 [ 3863 ] {5f3434c8-1c12-46a0-bd8d-df80ec71216b} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayPartialSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.651403 [ 3863 ] {4b2711d7-93cf-4237-9c90-f34480054a79} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayPopBack([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.652499 [ 3863 ] {4b2711d7-93cf-4237-9c90-f34480054a79} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 3, should be 1: In scope SELECT arrayPopBack([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:39.687720 [ 3863 ] {0b2f158e-6f85-49c8-8153-c735cbc5e39c} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayPopFront([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.688953 [ 3863 ] {0b2f158e-6f85-49c8-8153-c735cbc5e39c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 3, should be 1: In scope SELECT arrayPopFront([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:39.713691 [ 3863 ] {507c8797-b898-4984-9a96-f72bf87237e3} executeQuery: Code: 43. DB::Exception: First argument for function arrayProduct must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayProduct([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayProduct([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.714859 [ 3863 ] {507c8797-b898-4984-9a96-f72bf87237e3} TCPHandler: Code: 43. DB::Exception: First argument for function arrayProduct must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayProduct([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.739200 [ 3863 ] {f0e623dd-18ef-4ff2-990f-f65fd0136259} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayPushBack([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.740249 [ 3863 ] {f0e623dd-18ef-4ff2-990f-f65fd0136259} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 3, should be 2: In scope SELECT arrayPushBack([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:39.764586 [ 3863 ] {f79cc6d7-60f2-4599-9ce8-7085dc22bb6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayPushFront([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.765613 [ 3863 ] {f79cc6d7-60f2-4599-9ce8-7085dc22bb6c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 3, should be 2: In scope SELECT arrayPushFront([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:39.789990 [ 3863 ] {1190223c-a74b-4616-9628-42e785435cde} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayRandomSample([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.790984 [ 3863 ] {1190223c-a74b-4616-9628-42e785435cde} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 3, should be 2: In scope SELECT arrayRandomSample([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:39.817879 [ 3863 ] {6c04f80b-0ab8-4a59-ba72-053806c08015} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayReduce([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.819462 [ 3863 ] {6c04f80b-0ab8-4a59-ba72-053806c08015} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.846935 [ 3863 ] {429ba367-308f-455d-800e-844570ca70b6} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduceInRanges must be constant string: name of aggregate function.: In scope SELECT arrayReduceInRanges([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayReduceInRanges([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.848509 [ 3863 ] {429ba367-308f-455d-800e-844570ca70b6} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduceInRanges must be constant string: name of aggregate function.: In scope SELECT arrayReduceInRanges([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.878304 [ 3863 ] {f144b21a-af5f-4822-ba4f-a2a015fc772b} executeQuery: Code: 43. DB::Exception: Argument 1 for function arrayResize must be integer but it has type Array(Nullable(Nothing)).: In scope SELECT arrayResize([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayResize([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.879793 [ 3863 ] {f144b21a-af5f-4822-ba4f-a2a015fc772b} TCPHandler: Code: 43. DB::Exception: Argument 1 for function arrayResize must be integer but it has type Array(Nullable(Nothing)).: In scope SELECT arrayResize([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.906642 [ 3863 ] {bfd39b7f-1315-4c66-9620-f85d9cdf4678} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayReverse([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.907953 [ 3863 ] {bfd39b7f-1315-4c66-9620-f85d9cdf4678} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 3, should be 1: In scope SELECT arrayReverse([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:39.933429 [ 3863 ] {6dcc7c0f-b8c1-4e0c-a8a7-377c4e83e67b} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseFill must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseFill([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayReverseFill([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.934809 [ 3863 ] {6dcc7c0f-b8c1-4e0c-a8a7-377c4e83e67b} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseFill must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseFill([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:39.964183 [ 3863 ] {c89c3a22-db55-426f-90fe-f44ab0b837ad} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayReverseSort([NULL], [NULL], [NULL]);) 2025.03.31 19:00:39.965631 [ 3863 ] {c89c3a22-db55-426f-90fe-f44ab0b837ad} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseSort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:40.019053 [ 3863 ] {023bbdb4-791e-4c74-932b-a43a711bad13} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseSplit must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseSplit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayReverseSplit([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.020742 [ 3863 ] {023bbdb4-791e-4c74-932b-a43a711bad13} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseSplit must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arrayReverseSplit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:40.138256 [ 3863 ] {e49de062-c387-4c47-b96f-66a48f5977f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayRotateLeft([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.139605 [ 3863 ] {e49de062-c387-4c47-b96f-66a48f5977f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 3, should be 2: In scope SELECT arrayRotateLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.168432 [ 3863 ] {cb696d9a-e28e-47d5-8a55-5adeb4110bef} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayRotateRight([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.169928 [ 3863 ] {cb696d9a-e28e-47d5-8a55-5adeb4110bef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 3, should be 2: In scope SELECT arrayRotateRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.197663 [ 3863 ] {ece53829-f46d-49f2-a034-d9fdfbac65e0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function arrayShiftLeft, expected Native Integer: In scope SELECT arrayShiftLeft([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayShiftLeft([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.199333 [ 3863 ] {ece53829-f46d-49f2-a034-d9fdfbac65e0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function arrayShiftLeft, expected Native Integer: In scope SELECT arrayShiftLeft([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:40.228670 [ 3863 ] {875e6663-02dc-450c-b14d-708cd42b89f2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function arrayShiftRight, expected Native Integer: In scope SELECT arrayShiftRight([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayShiftRight([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.230043 [ 3863 ] {875e6663-02dc-450c-b14d-708cd42b89f2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function arrayShiftRight, expected Native Integer: In scope SELECT arrayShiftRight([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:40.347320 [ 3863 ] {53391fe0-7429-4693-a8e4-c81f552d0d6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayShingles([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.348530 [ 3863 ] {53391fe0-7429-4693-a8e4-c81f552d0d6c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 3, should be 2: In scope SELECT arrayShingles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.377455 [ 3863 ] {752d05e4-b45f-4d09-a0ab-69c451b6905c} executeQuery: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayShuffle([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.378802 [ 3863 ] {752d05e4-b45f-4d09-a0ab-69c451b6905c} TCPHandler: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 3.: In scope SELECT arrayShuffle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.407903 [ 3863 ] {696df60f-e9af-4811-93e5-08dde075991c} executeQuery: Code: 43. DB::Exception: Argument 1 for function arraySlice must be integer but it has type Array(Nullable(Nothing)).: In scope SELECT arraySlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arraySlice([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.409156 [ 3863 ] {696df60f-e9af-4811-93e5-08dde075991c} TCPHandler: Code: 43. DB::Exception: Argument 1 for function arraySlice must be integer but it has type Array(Nullable(Nothing)).: In scope SELECT arraySlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:40.438640 [ 3863 ] {12f7b49c-d50d-4a06-9289-dd5870833fb6} executeQuery: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arraySort([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.439861 [ 3863 ] {12f7b49c-d50d-4a06-9289-dd5870833fb6} TCPHandler: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:40.469429 [ 3863 ] {bd6a119c-c0ce-48e3-870d-af9ed116478a} executeQuery: Code: 43. DB::Exception: First argument for function arraySplit must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySplit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arraySplit([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.470819 [ 3863 ] {bd6a119c-c0ce-48e3-870d-af9ed116478a} TCPHandler: Code: 43. DB::Exception: First argument for function arraySplit must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySplit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:40.500540 [ 3863 ] {d0aedb6a-098c-465a-9539-145fc6a1f466} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT arrayStringConcat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayStringConcat([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.501956 [ 3863 ] {d0aedb6a-098c-465a-9539-145fc6a1f466} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT arrayStringConcat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.541356 [ 3863 ] {e5881741-73eb-4b33-aa7b-2f496a0b9f01} executeQuery: Code: 43. DB::Exception: First argument for function arraySum must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySum([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arraySum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.542896 [ 3863 ] {e5881741-73eb-4b33-aa7b-2f496a0b9f01} TCPHandler: Code: 43. DB::Exception: First argument for function arraySum must be a function. Actual Array(Nullable(Nothing)): In scope SELECT arraySum([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:40.628313 [ 3863 ] {3dd61747-5543-4984-85c3-ac991e724aa5} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT arrayWithConstant([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.629532 [ 3863 ] {3dd61747-5543-4984-85c3-ac991e724aa5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 3, should be 2: In scope SELECT arrayWithConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.697247 [ 3863 ] {1f17cba9-e896-4ab3-bfda-e5b2a09d8a90} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT array_agg([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.698568 [ 3863 ] {1f17cba9-e896-4ab3-bfda-e5b2a09d8a90} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.838553 [ 3863 ] {15beadbb-14c7-482e-b046-5deb12fc4273} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ascii([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.839776 [ 3863 ] {15beadbb-14c7-482e-b046-5deb12fc4273} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 3, should be 1: In scope SELECT ascii([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.866710 [ 3863 ] {7a39439a-d4e5-416b-8c27-74159334b3d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT asin([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.868112 [ 3863 ] {7a39439a-d4e5-416b-8c27-74159334b3d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 3, should be 1: In scope SELECT asin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.896401 [ 3863 ] {7b858329-e981-4a39-bd35-af4a837873e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT asinh([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.897440 [ 3863 ] {7b858329-e981-4a39-bd35-af4a837873e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 3, should be 1: In scope SELECT asinh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.926776 [ 3863 ] {587c7746-b0a6-43da-9c0f-ba0c408a9f6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT assumeNotNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.928161 [ 3863 ] {587c7746-b0a6-43da-9c0f-ba0c408a9f6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 3, should be 1: In scope SELECT assumeNotNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.957517 [ 3863 ] {acddcc85-3cb7-46b5-9a33-2855a9b16fcc} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT atan([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.958967 [ 3863 ] {acddcc85-3cb7-46b5-9a33-2855a9b16fcc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 3, should be 1: In scope SELECT atan([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:40.987776 [ 3863 ] {808fbcb7-d91e-437a-8b99-a7b0531aa7ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT atan2([NULL], [NULL], [NULL]);) 2025.03.31 19:00:40.989076 [ 3863 ] {808fbcb7-d91e-437a-8b99-a7b0531aa7ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 3, should be 2: In scope SELECT atan2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.017332 [ 3863 ] {bfc31722-550a-47ae-8920-bd7022933aca} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT atanh([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.018447 [ 3863 ] {bfc31722-550a-47ae-8920-bd7022933aca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 3, should be 1: In scope SELECT atanh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.047510 [ 3863 ] {2e2f47b2-0e5f-414d-acde-2261f58bd512} executeQuery: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT avg([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.048583 [ 3863 ] {2e2f47b2-0e5f-414d-acde-2261f58bd512} TCPHandler: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.077231 [ 3863 ] {2d083c6b-aee2-4b74-a3a1-bbe22d944f98} executeQuery: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT avgWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.078719 [ 3863 ] {2d083c6b-aee2-4b74-a3a1-bbe22d944f98} TCPHandler: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.108076 [ 3863 ] {85b4fc4e-d929-48ff-93fe-6231c3f071f7} executeQuery: Code: 43. DB::Exception: All arguments for function bar must be numeric.: In scope SELECT bar([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bar([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.109567 [ 3863 ] {85b4fc4e-d929-48ff-93fe-6231c3f071f7} TCPHandler: Code: 43. DB::Exception: All arguments for function bar must be numeric.: In scope SELECT bar([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:41.134368 [ 3863 ] {c47cc05b-2668-44a6-8b9b-0aeaa8a5b42f} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT base58Decode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.136605 [ 3863 ] {c47cc05b-2668-44a6-8b9b-0aeaa8a5b42f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 3, should be 1: In scope SELECT base58Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.160912 [ 3863 ] {fb2db942-dbb6-4832-ad0a-eea90a8d46a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT base58Encode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.161997 [ 3863 ] {fb2db942-dbb6-4832-ad0a-eea90a8d46a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 3, should be 1: In scope SELECT base58Encode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.184807 [ 3863 ] {03100068-1144-4081-9ee8-835f02482089} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT base64Decode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.185908 [ 3863 ] {03100068-1144-4081-9ee8-835f02482089} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 3, should be 1: In scope SELECT base64Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.208460 [ 3863 ] {6fc72c52-3334-4759-b357-95ceea83f55a} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT base64Encode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.209503 [ 3863 ] {6fc72c52-3334-4759-b357-95ceea83f55a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 3, should be 1: In scope SELECT base64Encode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.254450 [ 3863 ] {7453b369-78ba-4e1b-88d1-c5e67c6d60df} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT base64URLDecode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.255540 [ 3863 ] {7453b369-78ba-4e1b-88d1-c5e67c6d60df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 3, should be 1: In scope SELECT base64URLDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.318073 [ 3831 ] {54733715-ea73-4b48-b6a0-0459d75b116a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39666) (comment: 02242_case_insensitive_column_matching.sh) (in query: DROP DATABASE IF EXISTS test_63g9yp2o ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:41.319502 [ 3831 ] {54733715-ea73-4b48-b6a0-0459d75b116a} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:41.336152 [ 2854 ] {c5193b95-3370-431f-8bb3-fa234cf061f6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39680) (comment: 02242_case_insensitive_column_matching.sh) (in query: DROP DATABASE IF EXISTS test_63g9yp2o ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:00:41.338096 [ 2854 ] {c5193b95-3370-431f-8bb3-fa234cf061f6} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:41.354229 [ 3863 ] {ea3a594b-26ce-4391-b2c7-3ca68bb0e242} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT base64URLEncode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.355561 [ 3863 ] {ea3a594b-26ce-4391-b2c7-3ca68bb0e242} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 3, should be 1: In scope SELECT base64URLEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.381672 [ 3863 ] {63ecb8cb-592f-4698-abb6-6389aeffa517} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT basename([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.382910 [ 3863 ] {63ecb8cb-592f-4698-abb6-6389aeffa517} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 3, should be 1: In scope SELECT basename([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.405609 [ 3863 ] {f9711da9-d7fe-442f-becb-d1f28cf2120a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bin([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.406858 [ 3863 ] {f9711da9-d7fe-442f-becb-d1f28cf2120a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 3, should be 1: In scope SELECT bin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.434121 [ 3863 ] {3886d87a-6b2e-4dd4-9997-a9f060f1bb1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitAnd([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.435362 [ 3863 ] {3886d87a-6b2e-4dd4-9997-a9f060f1bb1b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 3, should be 2: In scope SELECT bitAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.459772 [ 3863 ] {8c73f977-9116-4f08-9d28-efdfad67a899} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitCount([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.460995 [ 3863 ] {8c73f977-9116-4f08-9d28-efdfad67a899} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 3, should be 1: In scope SELECT bitCount([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.483917 [ 3863 ] {1bf3c189-e3e4-48b7-8994-deaf1a791920} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitHammingDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.484972 [ 3863 ] {1bf3c189-e3e4-48b7-8994-deaf1a791920} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 3, should be 2: In scope SELECT bitHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.508906 [ 3863 ] {526d7d34-9d25-4ab2-9240-73c1bcd8a992} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitNot([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.511453 [ 3863 ] {526d7d34-9d25-4ab2-9240-73c1bcd8a992} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 3, should be 1: In scope SELECT bitNot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.535412 [ 3863 ] {8547fe58-4b5a-4ea7-b72d-83c059967e6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitOr([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.536535 [ 3863 ] {8547fe58-4b5a-4ea7-b72d-83c059967e6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 3, should be 2: In scope SELECT bitOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.563040 [ 3863 ] {415a56d7-1ac5-4601-a585-93c012738d84} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitPositionsToArray([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.564168 [ 3863 ] {415a56d7-1ac5-4601-a585-93c012738d84} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 3, should be 1: In scope SELECT bitPositionsToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.588332 [ 3863 ] {bb0667e7-0b84-46e1-a577-cdccde4e5a6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitRotateLeft([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.589598 [ 3863 ] {bb0667e7-0b84-46e1-a577-cdccde4e5a6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 3, should be 2: In scope SELECT bitRotateLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.614622 [ 3863 ] {a32460f6-3a3c-4d99-98c2-c8f4085391ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitRotateRight([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.616019 [ 3863 ] {a32460f6-3a3c-4d99-98c2-c8f4085391ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 3, should be 2: In scope SELECT bitRotateRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.641913 [ 3863 ] {a9785072-262e-4c1b-877d-1098d3196089} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitShiftLeft([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.643186 [ 3863 ] {a9785072-262e-4c1b-877d-1098d3196089} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 3, should be 2: In scope SELECT bitShiftLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.667426 [ 3863 ] {ebf000d2-7215-41a8-8add-31669dc2dfc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitShiftRight([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.668505 [ 3863 ] {ebf000d2-7215-41a8-8add-31669dc2dfc8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 3, should be 2: In scope SELECT bitShiftRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.693591 [ 3863 ] {ef838dde-dcbb-410c-be0f-83043c073e80} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT bitSlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitSlice([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.694931 [ 3863 ] {ef838dde-dcbb-410c-be0f-83043c073e80} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT bitSlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:41.720855 [ 3863 ] {7b579a4a-80c6-488e-b626-ecb830316a76} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitTest([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.722436 [ 3863 ] {7b579a4a-80c6-488e-b626-ecb830316a76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 3, should be 2: In scope SELECT bitTest([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.748596 [ 3863 ] {58e5872e-eaa8-451a-a501-7f817b77a9a8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function bitTestAll: In scope SELECT bitTestAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitTestAll([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.749835 [ 3863 ] {58e5872e-eaa8-451a-a501-7f817b77a9a8} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function bitTestAll: In scope SELECT bitTestAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:41.773644 [ 3863 ] {aef30827-47ac-4df2-9aad-1cf754c275af} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function bitTestAny: In scope SELECT bitTestAny([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitTestAny([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.775076 [ 3863 ] {aef30827-47ac-4df2-9aad-1cf754c275af} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function bitTestAny: In scope SELECT bitTestAny([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:41.798309 [ 3863 ] {acfe1981-afdf-4040-b7af-13afd9928063} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitXor([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.799459 [ 3863 ] {acfe1981-afdf-4040-b7af-13afd9928063} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 3, should be 2: In scope SELECT bitXor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.822056 [ 3863 ] {3610f615-7593-4feb-b747-ab0643a66532} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapAnd([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.823211 [ 3863 ] {3610f615-7593-4feb-b747-ab0643a66532} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 3, should be 2: In scope SELECT bitmapAnd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.847383 [ 3863 ] {414c0551-710f-4698-9298-9fba2492c734} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapAndCardinality([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.848677 [ 3863 ] {414c0551-710f-4698-9298-9fba2492c734} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.871892 [ 3863 ] {041176f6-2795-4ca1-a2c9-4421da4ebc28} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapAndnot([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.872969 [ 3863 ] {041176f6-2795-4ca1-a2c9-4421da4ebc28} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.956585 [ 3863 ] {15a1701c-7d4d-4f74-99d0-88b140e1d9a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapAndnotCardinality([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.957964 [ 3863 ] {15a1701c-7d4d-4f74-99d0-88b140e1d9a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapAndnotCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:41.986290 [ 3863 ] {0b92e33c-7483-4a48-9dd9-75ee695184dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapBuild([NULL], [NULL], [NULL]);) 2025.03.31 19:00:41.987503 [ 3863 ] {0b92e33c-7483-4a48-9dd9-75ee695184dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 3, should be 1: In scope SELECT bitmapBuild([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.016537 [ 3863 ] {916ac04c-4a43-4300-a5fe-f8bec4582904} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapCardinality([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.017965 [ 3863 ] {916ac04c-4a43-4300-a5fe-f8bec4582904} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 3, should be 1: In scope SELECT bitmapCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.115678 [ 3863 ] {b4e18698-004f-4489-b418-027003afa274} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapContains([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.117045 [ 3863 ] {b4e18698-004f-4489-b418-027003afa274} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 3, should be 2: In scope SELECT bitmapContains([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.143958 [ 3863 ] {24521c87-5cf0-4f1a-8fdb-9276acfe9d6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapHasAll([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.145161 [ 3863 ] {24521c87-5cf0-4f1a-8fdb-9276acfe9d6a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.172350 [ 3863 ] {26656f72-be45-4484-8087-8b445c67b6bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapHasAny([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.175599 [ 3863 ] {26656f72-be45-4484-8087-8b445c67b6bc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 3, should be 2: In scope SELECT bitmapHasAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.200258 [ 3863 ] {91b4a707-f6b0-4272-9c5f-968619c3a363} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapMax([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.310516 [ 3831 ] {8541099f-a629-4da5-8c2a-806b8332e751} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39692) (comment: 02242_case_insensitive_column_matching.sh) (in query: DROP DATABASE IF EXISTS test_63g9yp2o ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:00:42.310674 [ 3863 ] {91b4a707-f6b0-4272-9c5f-968619c3a363} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 3, should be 1: In scope SELECT bitmapMax([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.312216 [ 3831 ] {8541099f-a629-4da5-8c2a-806b8332e751} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:42.426913 [ 3863 ] {61632852-5fe2-4c45-8908-afeeed5f01e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapMin([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.428311 [ 3863 ] {61632852-5fe2-4c45-8908-afeeed5f01e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 3, should be 1: In scope SELECT bitmapMin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.454868 [ 3863 ] {f20ef540-98d4-4fb7-b29d-c4f9234e448e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapOr([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.456113 [ 3863 ] {f20ef540-98d4-4fb7-b29d-c4f9234e448e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 3, should be 2: In scope SELECT bitmapOr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.483063 [ 3863 ] {683e5987-c2a4-4332-bbfa-060e6145be7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapOrCardinality([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.484295 [ 3863 ] {683e5987-c2a4-4332-bbfa-060e6145be7c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapOrCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.512433 [ 3863 ] {e2b378c5-e3bd-4fff-b046-f61a65e6fa9b} executeQuery: Code: 43. DB::Exception: First argument for function bitmapSubsetInRange must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapSubsetInRange([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapSubsetInRange([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.513656 [ 3863 ] {e2b378c5-e3bd-4fff-b046-f61a65e6fa9b} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapSubsetInRange must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapSubsetInRange([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:42.538586 [ 3863 ] {cb5e2195-214c-423f-a137-bde1f16f1aa3} executeQuery: Code: 43. DB::Exception: First argument for function bitmapSubsetLimit must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapSubsetLimit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapSubsetLimit([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.539741 [ 3863 ] {cb5e2195-214c-423f-a137-bde1f16f1aa3} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapSubsetLimit must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapSubsetLimit([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:42.567706 [ 3863 ] {907ac77a-8a4b-4822-9a96-6a36879f6f6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapToArray([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.569076 [ 3863 ] {907ac77a-8a4b-4822-9a96-6a36879f6f6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 3, should be 1: In scope SELECT bitmapToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.597803 [ 3863 ] {c29a4549-451a-4f41-97fa-1a14c5f654a2} executeQuery: Code: 43. DB::Exception: First argument for function bitmapTransform must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapTransform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapTransform([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.598910 [ 3863 ] {c29a4549-451a-4f41-97fa-1a14c5f654a2} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapTransform must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT bitmapTransform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:42.627077 [ 3863 ] {75a395aa-b11a-4831-a324-102bbe0ef715} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapXor([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.628166 [ 3863 ] {75a395aa-b11a-4831-a324-102bbe0ef715} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 3, should be 2: In scope SELECT bitmapXor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.654307 [ 3863 ] {7b37609d-6157-401d-92bb-f69ed0eed9bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmapXorCardinality([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.655396 [ 3863 ] {7b37609d-6157-401d-92bb-f69ed0eed9bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 3, should be 2: In scope SELECT bitmapXorCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.758844 [ 3863 ] {0ac7b5b2-2231-4efa-8d06-04f0b1287944} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmaskToArray([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.759943 [ 3863 ] {0ac7b5b2-2231-4efa-8d06-04f0b1287944} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 3, should be 1: In scope SELECT bitmaskToArray([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.787682 [ 3863 ] {8a8b4a02-5724-4445-86ca-62aed642c71d} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT bitmaskToList([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.788962 [ 3863 ] {8a8b4a02-5724-4445-86ca-62aed642c71d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 3, should be 1: In scope SELECT bitmaskToList([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.814699 [ 3863 ] {21af08b5-fbff-45e2-aaca-f784328555d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT blockNumber([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.816070 [ 3863 ] {21af08b5-fbff-45e2-aaca-f784328555d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 3, should be 0: In scope SELECT blockNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.946597 [ 3831 ] {c2948dcc-5f1c-4773-87f4-f6d39c362a1f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35282) (comment: 01710_aggregate_projections.sh) (in query: select x + y + 1, argMax(y, x), sum(x - y) as s from test_agg_proj group by x + y + 1 order by s desc limit 5 settings optimize_use_projections=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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:42.948929 [ 3831 ] {c2948dcc-5f1c-4773-87f4-f6d39c362a1f} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:42.951145 [ 3863 ] {2f388862-c209-45a1-a2a9-f2960c27ddcb} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT blockSize([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.952681 [ 3863 ] {2f388862-c209-45a1-a2a9-f2960c27ddcb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 3, should be 0: In scope SELECT blockSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:42.976746 [ 3863 ] {576f3928-6789-4c9e-ac0d-99e5660a9ba8} executeQuery: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT boundingRatio([NULL], [NULL], [NULL]);) 2025.03.31 19:00:42.978060 [ 3863 ] {576f3928-6789-4c9e-ac0d-99e5660a9ba8} TCPHandler: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.064007 [ 3863 ] {6544f0df-5eec-4705-b1b2-c8f919bd026b} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT buildId([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.065349 [ 3863 ] {6544f0df-5eec-4705-b1b2-c8f919bd026b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 3, should be 0: In scope SELECT buildId([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.092061 [ 3863 ] {eba7651d-6be9-4172-8f6a-d8192ae6f426} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT byteHammingDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.093293 [ 3863 ] {eba7651d-6be9-4172-8f6a-d8192ae6f426} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT byteHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.152711 [ 3863 ] {e17717cc-fb57-4b5f-974f-107184072b5a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT byteSlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT byteSlice([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.154188 [ 3863 ] {e17717cc-fb57-4b5f-974f-107184072b5a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT byteSlice([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:43.178240 [ 3863 ] {c2a7b4b0-9451-4070-a9ba-1e9c0c331ab7} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT byteSwap([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.179346 [ 3863 ] {c2a7b4b0-9451-4070-a9ba-1e9c0c331ab7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 3, should be 1: In scope SELECT byteSwap([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.208727 [ 3863 ] {e75ef025-5753-44cb-8f96-c61eff617a3c} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nullable(Nothing)) in function 'transform': In scope SELECT caseWithExpr([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT caseWithExpr([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.210130 [ 3863 ] {e75ef025-5753-44cb-8f96-c61eff617a3c} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nullable(Nothing)) in function 'transform': In scope SELECT caseWithExpr([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.03.31 19:00:43.237997 [ 3863 ] {b021cf43-e0e7-4a0c-8d8d-6ab997932398} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nullable(Nothing)) in function 'transform': In scope SELECT caseWithExpression([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT caseWithExpression([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.239078 [ 3863 ] {b021cf43-e0e7-4a0c-8d8d-6ab997932398} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nullable(Nothing)) in function 'transform': In scope SELECT caseWithExpression([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.03.31 19:00:43.370849 [ 3863 ] {5dfbb63f-7728-4ca6-a2b3-ab79bd2e437b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT caseWithoutExpr([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.372110 [ 3863 ] {5dfbb63f-7728-4ca6-a2b3-ab79bd2e437b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:43.398434 [ 3863 ] {9782dee4-549a-4f72-9619-9999b5a9b2f4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpression([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT caseWithoutExpression([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.399745 [ 3863 ] {9782dee4-549a-4f72-9619-9999b5a9b2f4} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT caseWithoutExpression([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:43.447789 [ 3863 ] {b60b77a1-2466-4ee5-a8a4-735af831c5c3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT catboostEvaluate([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.450657 [ 3863 ] {b60b77a1-2466-4ee5-a8a4-735af831c5c3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:43.473745 [ 3863 ] {86b1ebec-6e73-4c51-b1d0-30dee2669302} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT categoricalInformationValue([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.475036 [ 3863 ] {86b1ebec-6e73-4c51-b1d0-30dee2669302} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:43.500041 [ 3863 ] {8ac74218-6473-4a65-8d71-93d14ac6f590} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cbrt([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.501220 [ 3863 ] {8ac74218-6473-4a65-8d71-93d14ac6f590} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 3, should be 1: In scope SELECT cbrt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.529047 [ 3863 ] {a6ccbf94-3701-45d4-a474-ab03d1caa53c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceil([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ceil([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.530719 [ 3863 ] {a6ccbf94-3701-45d4-a474-ab03d1caa53c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceil([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.558274 [ 3863 ] {5531979d-ceef-4a93-b298-46379722dd78} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceiling([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ceiling([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.559842 [ 3863 ] {5531979d-ceef-4a93-b298-46379722dd78} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT ceiling([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.585138 [ 3863 ] {94966fdc-a730-456e-9cc3-94efc615e1e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT changeDay([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.586963 [ 3863 ] {94966fdc-a730-456e-9cc3-94efc615e1e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 3, should be 2: In scope SELECT changeDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.611065 [ 3863 ] {17f65417-e33a-48ac-a963-b23419a8f90a} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT changeHour([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.612579 [ 3863 ] {17f65417-e33a-48ac-a963-b23419a8f90a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 3, should be 2: In scope SELECT changeHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.640402 [ 3863 ] {920c0cd2-364d-4715-8b8c-15936ab23e9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT changeMinute([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.641459 [ 3863 ] {920c0cd2-364d-4715-8b8c-15936ab23e9b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 3, should be 2: In scope SELECT changeMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.664204 [ 3863 ] {6e67db3e-86d6-46e7-a969-5a70b04b6e3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT changeMonth([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.665239 [ 3863 ] {6e67db3e-86d6-46e7-a969-5a70b04b6e3c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 3, should be 2: In scope SELECT changeMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.687117 [ 3863 ] {b536a38f-7838-48de-b889-f9ca1b80a7bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT changeSecond([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.688196 [ 3863 ] {b536a38f-7838-48de-b889-f9ca1b80a7bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 3, should be 2: In scope SELECT changeSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.710449 [ 3863 ] {f13baacc-193e-4984-b65e-0d6aef21ca5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT changeYear([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.711504 [ 3863 ] {f13baacc-193e-4984-b65e-0d6aef21ca5d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 3, should be 2: In scope SELECT changeYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:43.734289 [ 3863 ] {0fdbd12d-0694-424d-8d24-3bb73f2ba67f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function char, must be Int, UInt or Float number: In scope SELECT char([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT char([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.735369 [ 3863 ] {0fdbd12d-0694-424d-8d24-3bb73f2ba67f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function char, must be Int, UInt or Float number: In scope SELECT char([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:43.762236 [ 3863 ] {2b98edb5-4863-4905-ac3d-66e71c95ec11} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT cityHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cityHash64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:43.763377 [ 3863 ] {2b98edb5-4863-4905-ac3d-66e71c95ec11} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT cityHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:00:44.125975 [ 3863 ] {dd287ff4-1717-4d1e-85ed-611408549b0b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT concatWithSeparator([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.127336 [ 3863 ] {dd287ff4-1717-4d1e-85ed-611408549b0b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:44.154294 [ 3863 ] {6628a04a-a86e-4d2a-88a2-09a3846faaf3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT concatWithSeparatorAssumeInjective([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.155568 [ 3863 ] {6628a04a-a86e-4d2a-88a2-09a3846faaf3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:44.181570 [ 3863 ] {cb0ad750-80e7-4af9-9859-132c9fa7f788} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparator: In scope SELECT concat_ws([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT concat_ws([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.183312 [ 3863 ] {cb0ad750-80e7-4af9-9859-132c9fa7f788} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function concatWithSeparator: In scope SELECT concat_ws([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:44.209493 [ 3863 ] {7a83fcf1-7f17-4a2c-b0e3-e46d42e1b5c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT connectionId([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.210998 [ 3863 ] {7a83fcf1-7f17-4a2c-b0e3-e46d42e1b5c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connectionId([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.301594 [ 3863 ] {c47496f7-19d7-40f1-a1e9-710db57465ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT connection_id([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.303022 [ 3863 ] {c47496f7-19d7-40f1-a1e9-710db57465ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 3, should be 0: In scope SELECT connection_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.418183 [ 3863 ] {3bca9e60-e0b1-4886-9914-fadffd1bac76} executeQuery: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT contingency([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.419380 [ 3863 ] {3bca9e60-e0b1-4886-9914-fadffd1bac76} TCPHandler: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.440073 [ 2854 ] {f52c9bb8-2fd2-44ba-8ba8-0717d957b0fe} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35312) (comment: 00001_count_hits.sql) (in query: SELECT count() 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:44.441985 [ 2854 ] {f52c9bb8-2fd2-44ba-8ba8-0717d957b0fe} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:44.446110 [ 3863 ] {c25a2563-bf8c-422b-acaf-85ffdd18706e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function convertCharset, must be String: In scope SELECT convertCharset([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT convertCharset([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.447323 [ 3863 ] {c25a2563-bf8c-422b-acaf-85ffdd18706e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function convertCharset, must be String: In scope SELECT convertCharset([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:44.473944 [ 3863 ] {e24ec702-bcfb-4fe9-b513-a3f8fe36cd99} executeQuery: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT corr([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.475420 [ 3863 ] {e24ec702-bcfb-4fe9-b513-a3f8fe36cd99} TCPHandler: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.501889 [ 3863 ] {9d2db17a-a418-4eb4-9321-709ba2758feb} executeQuery: Code: 43. DB::Exception: Aggregate function corrMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT corrMatrix([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.503304 [ 3863 ] {9d2db17a-a418-4eb4-9321-709ba2758feb} TCPHandler: Code: 43. DB::Exception: Aggregate function corrMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:44.526554 [ 3863 ] {da249927-baef-44d7-96d8-1813ad5707b9} executeQuery: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT corrStable([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.527657 [ 3863 ] {da249927-baef-44d7-96d8-1813ad5707b9} TCPHandler: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.570069 [ 3863 ] {6dd8db16-216f-4ae4-8407-98207d31bcda} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cos([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.571368 [ 3863 ] {6dd8db16-216f-4ae4-8407-98207d31bcda} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 3, should be 1: In scope SELECT cos([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.595649 [ 3863 ] {657e9992-da41-4d76-b391-cdac500be65a} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cosh([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.596901 [ 3863 ] {657e9992-da41-4d76-b391-cdac500be65a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 3, should be 1: In scope SELECT cosh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.625024 [ 3863 ] {0b763b8d-67c6-496e-9479-08d1285d10f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cosineDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.626401 [ 3863 ] {0b763b8d-67c6-496e-9479-08d1285d10f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 3, should be 2: In scope SELECT cosineDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.654410 [ 3863 ] {fafd1545-048e-49ba-a00e-521f99810ee5} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT count([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.655561 [ 3863 ] {fafd1545-048e-49ba-a00e-521f99810ee5} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.683816 [ 3863 ] {2c49da01-4927-440f-901f-e61ba9cf6077} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT countDigits([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.685118 [ 3863 ] {2c49da01-4927-440f-901f-e61ba9cf6077} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 3, should be 1: In scope SELECT countDigits([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.710150 [ 3863 ] {9f4b76dc-4676-4571-b493-440da9221633} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT countEqual([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.711700 [ 3863 ] {9f4b76dc-4676-4571-b493-440da9221633} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 3, should be 2: In scope SELECT countEqual([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.733017 [ 3863 ] {d2f97d3c-27db-46d8-bbe1-5507c63c2e02} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT countMatches([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.734165 [ 3863 ] {d2f97d3c-27db-46d8-bbe1-5507c63c2e02} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 3, should be 2: In scope SELECT countMatches([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.763215 [ 3863 ] {ca3946d4-3d0e-4eb5-bcbb-88d396f5134d} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT countMatchesCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.764314 [ 3863 ] {ca3946d4-3d0e-4eb5-bcbb-88d396f5134d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT countMatchesCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.789412 [ 3863 ] {0ac03cdf-4aac-4b10-a828-1a46d22b3de0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstrings: In scope SELECT countSubstrings([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT countSubstrings([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.790805 [ 3863 ] {0ac03cdf-4aac-4b10-a828-1a46d22b3de0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstrings: In scope SELECT countSubstrings([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:44.814030 [ 3863 ] {9173fa1c-9fe1-4d26-a137-2830578deb56} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstringsCaseInsensitive: In scope SELECT countSubstringsCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT countSubstringsCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.815180 [ 3863 ] {9173fa1c-9fe1-4d26-a137-2830578deb56} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstringsCaseInsensitive: In scope SELECT countSubstringsCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:44.828214 [ 3830 ] {9683a7ae-6ff0-4014-877b-e83abbd0c1eb} executeQuery: Code: 57. DB::Exception: Table test.hits_tinylog already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35336) (comment: 00077_log_tinylog_stripelog.sql) (in query: CREATE TABLE test.hits_tinylog (CounterID UInt32, AdvEngineID UInt8, RegionID UInt32, SearchPhrase String, UserID UInt64) ENGINE = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:00:44.829535 [ 3830 ] {9683a7ae-6ff0-4014-877b-e83abbd0c1eb} TCPHandler: Code: 57. DB::Exception: Table test.hits_tinylog 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:00:44.841295 [ 3863 ] {1e8921d3-8f36-4e90-a653-f375a4625561} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstringsCaseInsensitiveUTF8: In scope SELECT countSubstringsCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT countSubstringsCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.842617 [ 3863 ] {1e8921d3-8f36-4e90-a653-f375a4625561} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function countSubstringsCaseInsensitiveUTF8: In scope SELECT countSubstringsCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:44.865595 [ 3863 ] {7620432b-12cb-4116-9b41-8a43c877d139} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT covarPop([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.866849 [ 3863 ] {7620432b-12cb-4116-9b41-8a43c877d139} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:44.951359 [ 3863 ] {ac94e1d3-7329-482d-8f2d-e249e879c76a} executeQuery: Code: 43. DB::Exception: Aggregate function covarPopMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT covarPopMatrix([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.953060 [ 3863 ] {ac94e1d3-7329-482d-8f2d-e249e879c76a} TCPHandler: Code: 43. DB::Exception: Aggregate function covarPopMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:44.977981 [ 3863 ] {05af6f79-5879-46bf-844f-693fdaaf76ac} executeQuery: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT covarPopStable([NULL], [NULL], [NULL]);) 2025.03.31 19:00:44.979279 [ 3863 ] {05af6f79-5879-46bf-844f-693fdaaf76ac} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.003192 [ 3863 ] {1adc6913-e41b-4d37-ae46-ef612a99e5f6} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT covarSamp([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.004611 [ 3863 ] {1adc6913-e41b-4d37-ae46-ef612a99e5f6} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.029083 [ 3863 ] {4916372a-462d-4514-90d5-4d883f85bbb5} executeQuery: Code: 43. DB::Exception: Aggregate function covarSampMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT covarSampMatrix([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.030632 [ 3863 ] {4916372a-462d-4514-90d5-4d883f85bbb5} TCPHandler: Code: 43. DB::Exception: Aggregate function covarSampMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:45.053037 [ 3863 ] {de921d67-0131-4a0e-a1ea-1b670df28dd7} executeQuery: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT covarSampStable([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.054230 [ 3863 ] {de921d67-0131-4a0e-a1ea-1b670df28dd7} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.080015 [ 3863 ] {4a817428-b30a-48b8-8c18-95147c831c7c} executeQuery: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cramersV([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.081231 [ 3863 ] {4a817428-b30a-48b8-8c18-95147c831c7c} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.105899 [ 3863 ] {7fb26979-ccda-4bed-99ff-920f1bb35533} executeQuery: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cramersVBiasCorrected([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.107052 [ 3863 ] {7fb26979-ccda-4bed-99ff-920f1bb35533} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.130635 [ 3863 ] {d016e8f3-b67b-443a-b80c-3be517db2e03} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT curdate([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.131768 [ 3863 ] {d016e8f3-b67b-443a-b80c-3be517db2e03} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT curdate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.154715 [ 3863 ] {075a54bd-a61d-482c-bfa4-b2e8a8124815} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT currentDatabase([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.155935 [ 3863 ] {075a54bd-a61d-482c-bfa4-b2e8a8124815} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT currentDatabase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.208803 [ 3863 ] {7552ce48-90ff-4e5f-87d6-e6be9cf41c65} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT currentProfiles([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.210199 [ 3863 ] {7552ce48-90ff-4e5f-87d6-e6be9cf41c65} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 3, should be 0: In scope SELECT currentProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.236272 [ 3863 ] {54178dd9-6dfa-4a36-9c0d-ba464d1e2b46} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT currentRoles([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.237370 [ 3863 ] {54178dd9-6dfa-4a36-9c0d-ba464d1e2b46} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 3, should be 0: In scope SELECT currentRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.260551 [ 3863 ] {c6edeac6-1517-4bff-8380-5b4ca74c2a07} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT currentSchemas([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.261843 [ 3863 ] {c6edeac6-1517-4bff-8380-5b4ca74c2a07} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT currentSchemas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.287094 [ 3863 ] {104031d2-8648-426a-9aa4-afc3616273db} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT currentUser([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.288984 [ 3863 ] {104031d2-8648-426a-9aa4-afc3616273db} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT currentUser([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.313694 [ 3863 ] {2f380e03-d5df-42ed-b6da-8ca1104c86f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT current_database([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.314915 [ 3863 ] {2f380e03-d5df-42ed-b6da-8ca1104c86f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 3, should be 0: In scope SELECT current_database([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.339291 [ 3863 ] {42f42d35-579e-409f-96f1-b0ee18dba17f} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT current_date([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.340367 [ 3863 ] {42f42d35-579e-409f-96f1-b0ee18dba17f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT current_date([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.363347 [ 3863 ] {1b698f71-921d-4bc7-b582-d5d86ccb4322} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT current_schemas([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.364552 [ 3863 ] {1b698f71-921d-4bc7-b582-d5d86ccb4322} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 3, should be 1: In scope SELECT current_schemas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.392347 [ 3863 ] {a5533a25-5c67-4789-ac56-cf85e8fa9d08} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT current_timestamp([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.393601 [ 3863 ] {a5533a25-5c67-4789-ac56-cf85e8fa9d08} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.418394 [ 3863 ] {f9d3ab70-7862-434e-8d72-16f2e0ec604b} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT current_user([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.419461 [ 3863 ] {f9d3ab70-7862-434e-8d72-16f2e0ec604b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT current_user([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.445412 [ 3863 ] {50dd7daa-5c86-4f33-84cc-a035ff17935c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutFragment([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.446723 [ 3863 ] {50dd7daa-5c86-4f33-84cc-a035ff17935c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 3, should be 1: In scope SELECT cutFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.471532 [ 3863 ] {c549e83b-5f90-4ac9-9cbe-d7ecd4bcdecb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function cutIPv6, expected FixedString(16): In scope SELECT cutIPv6([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutIPv6([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.472658 [ 3863 ] {c549e83b-5f90-4ac9-9cbe-d7ecd4bcdecb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function cutIPv6, expected FixedString(16): In scope SELECT cutIPv6([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:45.497351 [ 3863 ] {de2fae33-fce1-4555-912c-ac91366e4e7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutQueryString([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.498814 [ 3863 ] {de2fae33-fce1-4555-912c-ac91366e4e7e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 3, should be 1: In scope SELECT cutQueryString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.578798 [ 3863 ] {05e06df9-facf-4d54-b428-ebb47f3c27b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutQueryStringAndFragment([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.580292 [ 3863 ] {05e06df9-facf-4d54-b428-ebb47f3c27b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT cutQueryStringAndFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.608604 [ 3863 ] {bd630bd5-349e-4e1e-8801-ebd9c30805ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutToFirstSignificantSubdomain([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.610108 [ 3863 ] {bd630bd5-349e-4e1e-8801-ebd9c30805ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.638467 [ 3863 ] {90cb7f3e-986d-4b08-afc7-031a94322fcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutToFirstSignificantSubdomainCustom([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.639834 [ 3863 ] {90cb7f3e-986d-4b08-afc7-031a94322fcd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.665346 [ 3863 ] {c251ebff-213f-498f-ae98-01a1a1011765} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.666518 [ 3863 ] {c251ebff-213f-498f-ae98-01a1a1011765} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.772388 [ 3863 ] {abdbe52d-7afe-4e5c-97a4-d46b3b6ca937} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.774476 [ 3863 ] {abdbe52d-7afe-4e5c-97a4-d46b3b6ca937} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.799056 [ 3863 ] {04fed78b-4017-494b-86f4-e25f0248f61b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.800707 [ 3863 ] {04fed78b-4017-494b-86f4-e25f0248f61b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 3, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.822893 [ 3863 ] {be22bf84-0a2f-44f9-a495-d7da99305232} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutToFirstSignificantSubdomainRFC([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.823992 [ 3863 ] {be22bf84-0a2f-44f9-a495-d7da99305232} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.848397 [ 3863 ] {904f069d-cba4-4b41-9190-3dd7966e9a11} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWW([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.849935 [ 3863 ] {904f069d-cba4-4b41-9190-3dd7966e9a11} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.875345 [ 3863 ] {29865b0a-4483-4468-9d25-56a6c56d3d00} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.876825 [ 3863 ] {29865b0a-4483-4468-9d25-56a6c56d3d00} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 3, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:45.901559 [ 3863 ] {7a846553-1467-447d-8c67-781d65c9b977} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutURLParameter([NULL], [NULL], [NULL]);) 2025.03.31 19:00:45.902824 [ 3863 ] {7a846553-1467-447d-8c67-781d65c9b977} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 3, should be 2: In scope SELECT cutURLParameter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.031779 [ 3863 ] {75b75911-fc8b-428a-84ff-7d3dfe4e0d98} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT cutWWW([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.033102 [ 3863 ] {75b75911-fc8b-428a-84ff-7d3dfe4e0d98} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 3, should be 1: In scope SELECT cutWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.060108 [ 3863 ] {8f5954ee-701c-48b7-967a-6cef355de144} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT damerauLevenshteinDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.061644 [ 3863 ] {8f5954ee-701c-48b7-967a-6cef355de144} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 3, should be 2: In scope SELECT damerauLevenshteinDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.088103 [ 3863 ] {f4ffb00a-7e0b-4dc8-b03b-ce93de2335ce} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dateDiff([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.089243 [ 3863 ] {f4ffb00a-7e0b-4dc8-b03b-ce93de2335ce} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:46.114842 [ 3863 ] {3cb510ed-463a-4046-bbcf-83cb5ed15b1d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1 argument of function dateName. Must be string: In scope SELECT dateName([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dateName([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.116467 [ 3863 ] {3cb510ed-463a-4046-bbcf-83cb5ed15b1d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1 argument of function dateName. Must be string: In scope SELECT dateName([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:46.141741 [ 3863 ] {945bf720-2312-47c4-af78-d0d1bd2903b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dateTime64ToSnowflake([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.143153 [ 3863 ] {945bf720-2312-47c4-af78-d0d1bd2903b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTime64ToSnowflake([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.167221 [ 3863 ] {ac80263a-4c54-43da-b0a2-d924b9c10f23} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTime64ToSnowflakeID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dateTime64ToSnowflakeID([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.168351 [ 3863 ] {ac80263a-4c54-43da-b0a2-d924b9c10f23} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTime64ToSnowflakeID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.192526 [ 3863 ] {25f05e5e-c8b4-4c64-9191-2f838127b262} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dateTimeToSnowflake([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.194085 [ 3863 ] {25f05e5e-c8b4-4c64-9191-2f838127b262} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 3, should be 1: In scope SELECT dateTimeToSnowflake([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.274528 [ 3863 ] {eea5af7c-1a1d-4d80-a563-a730f9b2c551} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTimeToSnowflakeID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dateTimeToSnowflakeID([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.275943 [ 3863 ] {eea5af7c-1a1d-4d80-a563-a730f9b2c551} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT dateTimeToSnowflakeID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.301353 [ 3863 ] {41ed2edb-d07b-4bef-84e0-94db0a9a45a7} executeQuery: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT dateTrunc([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dateTrunc([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.302586 [ 3863 ] {41ed2edb-d07b-4bef-84e0-94db0a9a45a7} TCPHandler: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT dateTrunc([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:46.328995 [ 3863 ] {691a78c6-521a-432d-8b38-485a227be028} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT date_diff([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.330625 [ 3863 ] {691a78c6-521a-432d-8b38-485a227be028} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:46.354589 [ 3863 ] {b57ca30c-ea50-412a-9aa9-c928d310becc} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT decodeHTMLComponent([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.355879 [ 3863 ] {b57ca30c-ea50-412a-9aa9-c928d310becc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeHTMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.382823 [ 3863 ] {8986669b-7c69-4186-8c8d-cb75ef1600cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT decodeURLComponent([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.384079 [ 3863 ] {8986669b-7c69-4186-8c8d-cb75ef1600cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.409691 [ 3863 ] {40ec4b83-8b5c-4750-9f25-a34c1d6df915} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT decodeURLFormComponent([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.411354 [ 3863 ] {40ec4b83-8b5c-4750-9f25-a34c1d6df915} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT decodeURLFormComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.435465 [ 3863 ] {109c8893-3c5d-4865-b30f-e383f66e98ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT decodeXMLComponent([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.436859 [ 3863 ] {109c8893-3c5d-4865-b30f-e383f66e98ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT decodeXMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.462399 [ 3863 ] {1160fe00-5351-4996-afda-b66b64ed6513} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'decrypt'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT decrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT decrypt([NULL], '[HIDDEN]')) 2025.03.31 19:00:46.463820 [ 3602 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fce196b8-b32c-4319-8cdf-3d340eb025b8::202503_1_56_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:46.463933 [ 3863 ] {1160fe00-5351-4996-afda-b66b64ed6513} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'decrypt'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT decrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:46.515902 [ 3863 ] {54a36556-467c-4262-8521-eff650b71aa4} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT defaultProfiles([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.517004 [ 3863 ] {54a36556-467c-4262-8521-eff650b71aa4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 3, should be 0: In scope SELECT defaultProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.539987 [ 3863 ] {47a100e3-17ff-43f6-97cd-b8490f53a447} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT defaultRoles([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.541112 [ 3863 ] {47a100e3-17ff-43f6-97cd-b8490f53a447} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 3, should be 0: In scope SELECT defaultRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.563295 [ 3863 ] {79627b9e-d3cb-40e8-b6c5-786f50c0f130} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT defaultValueOfArgumentType([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.564420 [ 3863 ] {79627b9e-d3cb-40e8-b6c5-786f50c0f130} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfArgumentType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.588225 [ 3863 ] {69328a2d-1ff6-4481-aaa4-827cffd0103b} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT defaultValueOfTypeName([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.589429 [ 3863 ] {69328a2d-1ff6-4481-aaa4-827cffd0103b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 3, should be 1: In scope SELECT defaultValueOfTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.615432 [ 3863 ] {1007778c-fbb5-4ece-9c05-a6bcaedc77a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT degrees([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.616633 [ 3863 ] {1007778c-fbb5-4ece-9c05-a6bcaedc77a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 3, should be 1: In scope SELECT degrees([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.639115 [ 3863 ] {a5fa0a6e-0e24-484c-b228-860abf691878} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT deltaSum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.640261 [ 3863 ] {a5fa0a6e-0e24-484c-b228-860abf691878} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.695260 [ 3863 ] {ae37581a-e834-49d4-864b-9c15fc89687a} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT deltaSumTimestamp([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.696702 [ 3863 ] {ae37581a-e834-49d4-864b-9c15fc89687a} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.817374 [ 3863 ] {e5066da7-fd9a-48df-bb14-527264b4e3e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT demangle([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.818780 [ 3863 ] {e5066da7-fd9a-48df-bb14-527264b4e3e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 3, should be 1: In scope SELECT demangle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:46.927856 [ 3863 ] {2ea31184-0171-465e-b905-5eecb83f15a1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT denseRank([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.929597 [ 3863 ] {2ea31184-0171-465e-b905-5eecb83f15a1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:00:46.940701 [ 3830 ] {42f051e1-da0e-4898-b4f2-60a29bb6949d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35430) (comment: 00005_filtering.sql) (in query: SELECT count() FROM test.hits WHERE AdvEngineID != 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:46.942705 [ 3830 ] {42f051e1-da0e-4898-b4f2-60a29bb6949d} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:46.968699 [ 3863 ] {b9f4a89b-c9c2-4f6d-aa71-72712622de62} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dense_rank([NULL], [NULL], [NULL]);) 2025.03.31 19:00:46.970493 [ 3863 ] {b9f4a89b-c9c2-4f6d-aa71-72712622de62} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.03.31 19:00:47.001090 [ 3863 ] {d134b4ee-0895-4f25-bcb6-7c0f7c0ece1d} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT detectCharset([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.002462 [ 3863 ] {d134b4ee-0895-4f25-bcb6-7c0f7c0ece1d} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:00:47.024792 [ 3863 ] {fb92172a-95d7-4d08-920c-1b1fc3ea07fc} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT detectLanguage([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.026080 [ 3863 ] {fb92172a-95d7-4d08-920c-1b1fc3ea07fc} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:00:47.048227 [ 3863 ] {ae462fd3-3ac7-4292-83db-292627a57c50} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT detectLanguageMixed([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.049365 [ 3863 ] {ae462fd3-3ac7-4292-83db-292627a57c50} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:00:47.071724 [ 3863 ] {1d00e155-19b1-4970-b6a6-75c31182002e} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT detectLanguageUnknown([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.072864 [ 3863 ] {1d00e155-19b1-4970-b6a6-75c31182002e} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:00:47.185322 [ 3863 ] {f2aece97-eb61-4255-93ab-e2bd7b631d21} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT detectProgrammingLanguage([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.186638 [ 3863 ] {f2aece97-eb61-4255-93ab-e2bd7b631d21} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:00:47.212387 [ 3863 ] {1c54902d-154f-4b4e-a3a6-c0c7a0fb6bcd} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT detectTonality([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.311431 [ 3863 ] {1c54902d-154f-4b4e-a3a6-c0c7a0fb6bcd} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:00:47.337082 [ 3863 ] {afecfefa-0da0-44b3-b233-071d2e9f3bfd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGet([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.338352 [ 3863 ] {afecfefa-0da0-44b3-b233-071d2e9f3bfd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGet([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.362567 [ 3863 ] {0e5dc23e-3859-4e1f-87b3-f6b5664d49b1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetAll([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.363618 [ 3863 ] {0e5dc23e-3859-4e1f-87b3-f6b5664d49b1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetAll, expected a const string.: In scope SELECT dictGetAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.388017 [ 3863 ] {ee598810-bc4e-4fe5-a59b-9c30aa85458f} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetChildren([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.389395 [ 3863 ] {ee598810-bc4e-4fe5-a59b-9c30aa85458f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 3, should be 2: In scope SELECT dictGetChildren([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:47.412467 [ 3863 ] {252560ea-b4d8-4383-99d9-f74a184deb72} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetDate([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.413700 [ 3863 ] {252560ea-b4d8-4383-99d9-f74a184deb72} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.437070 [ 3863 ] {e5f0adda-58b7-43cb-80ec-f0d9441b2757} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetDateOrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.438494 [ 3863 ] {e5f0adda-58b7-43cb-80ec-f0d9441b2757} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.530336 [ 3863 ] {b4c9f0bc-9a14-4a97-aa94-03f3a4c6b5b3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.531683 [ 3863 ] {b4c9f0bc-9a14-4a97-aa94-03f3a4c6b5b3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.555753 [ 3863 ] {4971353b-b525-4e50-86c7-dbb1c83c3615} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateTimeOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetDateTimeOrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.557124 [ 3863 ] {4971353b-b525-4e50-86c7-dbb1c83c3615} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetDateTimeOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.642333 [ 3863 ] {2ca160ef-851b-448f-b60b-d417e7703815} executeQuery: Code: 43. DB::Exception: Illegal type of first argument of function dictGetDescendants. Expected const String. Actual type Array(Nullable(Nothing)): In scope SELECT dictGetDescendants([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetDescendants([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.643796 [ 3863 ] {2ca160ef-851b-448f-b60b-d417e7703815} TCPHandler: Code: 43. DB::Exception: Illegal type of first argument of function dictGetDescendants. Expected const String. Actual type Array(Nullable(Nothing)): In scope SELECT dictGetDescendants([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.670363 [ 3863 ] {e558f433-dc4f-43b2-a3f3-d785c1999ddc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetFloat32([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.671668 [ 3863 ] {e558f433-dc4f-43b2-a3f3-d785c1999ddc} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.695187 [ 3863 ] {960b1034-aafa-4a2f-b3a0-ef2a42103674} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetFloat32OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.696283 [ 3863 ] {960b1034-aafa-4a2f-b3a0-ef2a42103674} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.723164 [ 3863 ] {320effb1-8957-48bf-8e75-411f6fe252a2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetFloat64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.724242 [ 3863 ] {320effb1-8957-48bf-8e75-411f6fe252a2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetFloat64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.747275 [ 3863 ] {4d67ca00-5493-46b8-82e2-189eb7389403} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetFloat64OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.748409 [ 3863 ] {4d67ca00-5493-46b8-82e2-189eb7389403} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetFloat64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.815972 [ 3863 ] {4644f240-31a9-4915-90ed-bceebdedca17} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetHierarchy([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.817108 [ 3863 ] {4644f240-31a9-4915-90ed-bceebdedca17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 3, should be 2: In scope SELECT dictGetHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:47.840911 [ 3863 ] {9163b9ff-c544-42d2-8a03-904ef4ecbc65} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv4([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetIPv4([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.842170 [ 3863 ] {9163b9ff-c544-42d2-8a03-904ef4ecbc65} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv4([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.864642 [ 3863 ] {1c4f144a-3e1a-41c2-89b2-f0db7d5fe5a9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv4OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetIPv4OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.865908 [ 3863 ] {1c4f144a-3e1a-41c2-89b2-f0db7d5fe5a9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv4OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.888424 [ 3863 ] {92d16355-f6a5-4b10-a44c-746618aa3dbd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv6([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetIPv6([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.889582 [ 3863 ] {92d16355-f6a5-4b10-a44c-746618aa3dbd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetIPv6([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.911939 [ 3863 ] {cfb725d3-c93d-4b6c-8e94-9695cccdcd1c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv6OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetIPv6OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.913073 [ 3863 ] {cfb725d3-c93d-4b6c-8e94-9695cccdcd1c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetIPv6OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.936008 [ 3863 ] {b47c5efa-fa55-4ed0-8018-49cf659f630a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt16([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetInt16([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.937250 [ 3863 ] {b47c5efa-fa55-4ed0-8018-49cf659f630a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt16([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.959574 [ 3863 ] {29f3b893-9937-4a1e-bdd3-e0009edb9d45} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt16OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetInt16OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.960759 [ 3863 ] {29f3b893-9937-4a1e-bdd3-e0009edb9d45} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt16OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:47.983293 [ 3863 ] {7e89408e-7bf2-44c4-922f-3f901905cbf3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetInt32([NULL], [NULL], [NULL]);) 2025.03.31 19:00:47.984516 [ 3863 ] {7e89408e-7bf2-44c4-922f-3f901905cbf3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.009126 [ 3863 ] {90e8e0a5-f781-4b5c-a057-6a6e8a606bd0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetInt32OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.010394 [ 3863 ] {90e8e0a5-f781-4b5c-a057-6a6e8a606bd0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.031624 [ 3863 ] {fd325de9-d0bc-4cdc-b3ee-adc02bd2aaa3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetInt64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.032675 [ 3863 ] {fd325de9-d0bc-4cdc-b3ee-adc02bd2aaa3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.086814 [ 3863 ] {ac71ea36-ceee-406b-b6d7-68130b38d070} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetInt64OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.088132 [ 3863 ] {ac71ea36-ceee-406b-b6d7-68130b38d070} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.110437 [ 3863 ] {8d9a8b3c-bd07-42ab-9e2d-0988257b75a8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetInt8([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.111594 [ 3863 ] {8d9a8b3c-bd07-42ab-9e2d-0988257b75a8} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetInt8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.136177 [ 3863 ] {b71eb312-fec1-4658-9076-d1b1a0333659} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt8OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetInt8OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.137556 [ 3863 ] {b71eb312-fec1-4658-9076-d1b1a0333659} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetInt8OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.159713 [ 3863 ] {f1be1efa-9624-49ac-8b00-4d33d1cb71bb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetOrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.160798 [ 3863 ] {f1be1efa-9624-49ac-8b00-4d33d1cb71bb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.182903 [ 3863 ] {e5c007a7-7253-459d-8dae-c140e8e69bb0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.184161 [ 3863 ] {e5c007a7-7253-459d-8dae-c140e8e69bb0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.203970 [ 3863 ] {7f6e10c3-0571-44a2-9993-59f645315fc7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetString([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.205026 [ 3863 ] {7f6e10c3-0571-44a2-9993-59f645315fc7} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.227101 [ 3863 ] {47ed77b4-5e17-48f6-a5bb-1e35bc3be099} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetStringOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetStringOrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.228212 [ 3863 ] {47ed77b4-5e17-48f6-a5bb-1e35bc3be099} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetStringOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.251761 [ 3863 ] {f2b93cff-200a-4e70-a64a-7e88f0131735} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt16([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetUInt16([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.253036 [ 3863 ] {f2b93cff-200a-4e70-a64a-7e88f0131735} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt16([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.275555 [ 3863 ] {bf17ce9a-3a78-444f-b838-c1f8548b770a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt16OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetUInt16OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.276748 [ 3863 ] {bf17ce9a-3a78-444f-b838-c1f8548b770a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt16OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.306999 [ 3863 ] {837a8be8-627c-476d-8721-99c2e2ecb787} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetUInt32([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.308360 [ 3863 ] {837a8be8-627c-476d-8721-99c2e2ecb787} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.332506 [ 3863 ] {744e2e69-e4bf-48de-85ed-969d3cc4961e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetUInt32OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.333621 [ 3863 ] {744e2e69-e4bf-48de-85ed-969d3cc4961e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.356997 [ 3863 ] {f69c1f6b-293e-42ad-95c8-0f639c264501} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetUInt64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.358212 [ 3863 ] {f69c1f6b-293e-42ad-95c8-0f639c264501} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.381176 [ 3863 ] {4c81166a-e857-4147-aba7-680416397b69} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetUInt64OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.382378 [ 3863 ] {4c81166a-e857-4147-aba7-680416397b69} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.404388 [ 3863 ] {50662022-47e6-4287-aaf9-741aaf63b4b1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetUInt8([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.405472 [ 3863 ] {50662022-47e6-4287-aaf9-741aaf63b4b1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUInt8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.427784 [ 3863 ] {3abad3c8-86f8-4173-b955-dc6aecf8c6cb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt8OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetUInt8OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.428832 [ 3863 ] {3abad3c8-86f8-4173-b955-dc6aecf8c6cb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUInt8OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.434423 [ 3830 ] {ce515b08-6994-465c-a999-7e0f50832331} 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.10457.altinitytest (altinity build)) (from [::1]:35472) (comment: 00072_compare_date_and_string_index.sql) (in query: SELECT count() FROM test.hits WHERE EventDate IN (toDate('2014-03-18'), toDate('2014-03-19'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:48.436983 [ 3830 ] {ce515b08-6994-465c-a999-7e0f50832331} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:48.450612 [ 3863 ] {b0d5db26-8879-4f30-87a7-8015d35ea74b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUUID([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetUUID([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.451709 [ 3863 ] {b0d5db26-8879-4f30-87a7-8015d35ea74b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGet, expected a const string.: In scope SELECT dictGetUUID([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.475377 [ 3863 ] {814019eb-24d9-4efc-a5db-6a05bb8e3124} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUUIDOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictGetUUIDOrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.476727 [ 3863 ] {814019eb-24d9-4efc-a5db-6a05bb8e3124} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictGetOrDefault, expected a const string.: In scope SELECT dictGetUUIDOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.500731 [ 3863 ] {45c8438e-fc58-45ad-a74b-bba098f6e17b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictHas, expected a string: In scope SELECT dictHas([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictHas([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.502210 [ 3863 ] {45c8438e-fc58-45ad-a74b-bba098f6e17b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function dictHas, expected a string: In scope SELECT dictHas([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.523989 [ 3863 ] {bb3fa1d5-8536-457f-969a-ebff364f8153} executeQuery: Code: 43. DB::Exception: Illegal type of first argument of function dictIsIn. Expected String. Actual type Array(Nullable(Nothing)): In scope SELECT dictIsIn([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dictIsIn([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.525050 [ 3863 ] {bb3fa1d5-8536-457f-969a-ebff364f8153} TCPHandler: Code: 43. DB::Exception: Illegal type of first argument of function dictIsIn. Expected String. Actual type Array(Nullable(Nothing)): In scope SELECT dictIsIn([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.546845 [ 3863 ] {9452b9ae-3c63-4858-ae60-63989afd0ae0} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT displayName([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.547940 [ 3863 ] {9452b9ae-3c63-4858-ae60-63989afd0ae0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 3, should be 0: In scope SELECT displayName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:48.570113 [ 3863 ] {a101f7bb-a520-4074-a9c9-9ec7791a2a9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT distanceL1([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.571327 [ 3863 ] {a101f7bb-a520-4074-a9c9-9ec7791a2a9e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:48.595873 [ 3863 ] {dd05c6ff-6cce-4ae1-890b-37b5bbf2b48d} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT distanceL2([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.597046 [ 3863 ] {dd05c6ff-6cce-4ae1-890b-37b5bbf2b48d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 3, should be 2: In scope SELECT distanceL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:48.712132 [ 3863 ] {09bf1f27-ba94-46b0-bba4-fd0287cdd829} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT distanceL2Squared([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.713496 [ 3863 ] {09bf1f27-ba94-46b0-bba4-fd0287cdd829} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 3, should be 2: In scope SELECT distanceL2Squared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:48.742076 [ 3863 ] {68cecc6c-3474-485c-b4e1-b9281f7d4763} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT distanceLinf([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.743492 [ 3863 ] {68cecc6c-3474-485c-b4e1-b9281f7d4763} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 3, should be 2: In scope SELECT distanceLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:48.767455 [ 3863 ] {fb98b767-a0b3-4eba-ab6d-e432424217e7} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nullable(Nothing). Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT distanceLp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT distanceLp([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.768589 [ 3863 ] {fb98b767-a0b3-4eba-ab6d-e432424217e7} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLpDistance has nested type Nullable(Nothing). Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT distanceLp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.793513 [ 3863 ] {1342e80e-e43e-46ad-aad1-bd843b0068c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT divide([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.795046 [ 3863 ] {1342e80e-e43e-46ad-aad1-bd843b0068c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 3, should be 2: In scope SELECT divide([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:48.813134 [ 4734 ] {9f86c863-e2f0-494f-b78c-168761cc7876} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness RightAny. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35484) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b85092a 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) @ 0x000000003b82e89a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b82f592 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b84ea71 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&) @ 0x00000000322a7a0f 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>>*) @ 0x000000003228ccb4 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be2e6fe 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 2025.03.31 19:00:48.815184 [ 4734 ] {9f86c863-e2f0-494f-b78c-168761cc7876} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b85092a 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) @ 0x000000003b82e89a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b82f592 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b84ea71 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&) @ 0x00000000322a7a0f 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>>*) @ 0x000000003228ccb4 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be2e6fe 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 2025.03.31 19:00:48.820149 [ 3863 ] {0f74a289-eca1-4485-9110-b8b447e37221} executeQuery: Code: 43. DB::Exception: Arguments for divideDecimal function must be Decimal: In scope SELECT divideDecimal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT divideDecimal([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.821126 [ 3863 ] {0f74a289-eca1-4485-9110-b8b447e37221} TCPHandler: Code: 43. DB::Exception: Arguments for divideDecimal function must be Decimal: In scope SELECT divideDecimal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:48.859073 [ 3863 ] {d5569488-6bc0-44a3-b38e-870d25692221} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT domain([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.860247 [ 3863 ] {d5569488-6bc0-44a3-b38e-870d25692221} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 3, should be 1: In scope SELECT domain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:48.884629 [ 3863 ] {2b0cbaf3-2f03-445b-9910-d28a1ab603fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT domainRFC([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.885678 [ 3863 ] {2b0cbaf3-2f03-445b-9910-d28a1ab603fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 3, should be 1: In scope SELECT domainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:48.907589 [ 3863 ] {a8dadd70-a3f4-4ca5-b33b-4168eef43a10} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT domainWithoutWWW([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.908388 [ 3863 ] {a8dadd70-a3f4-4ca5-b33b-4168eef43a10} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWW([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:48.930441 [ 3863 ] {de4491cd-74d7-4a7c-9bf0-7d0f35d13bc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT domainWithoutWWWRFC([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.931701 [ 3863 ] {de4491cd-74d7-4a7c-9bf0-7d0f35d13bc3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 3, should be 1: In scope SELECT domainWithoutWWWRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:48.955365 [ 3863 ] {b587946f-0258-4aaa-b81b-1cca8ce46fa2} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dotProduct([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.956390 [ 3863 ] {b587946f-0258-4aaa-b81b-1cca8ce46fa2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT dotProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:48.981897 [ 3863 ] {45076544-8227-4759-9722-ae7cb88e28d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dumpColumnStructure([NULL], [NULL], [NULL]);) 2025.03.31 19:00:48.983071 [ 3863 ] {45076544-8227-4759-9722-ae7cb88e28d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 3, should be 1: In scope SELECT dumpColumnStructure([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.010871 [ 3863 ] {ac9e7f9f-a70c-4eca-af90-6f6d783587ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dynamicElement([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.012278 [ 3863 ] {ac9e7f9f-a70c-4eca-af90-6f6d783587ec} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 3, should be 2: In scope SELECT dynamicElement([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.036633 [ 3863 ] {e612005e-93ab-419d-b890-701cfca27afc} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT dynamicType([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.037870 [ 3863 ] {e612005e-93ab-419d-b890-701cfca27afc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 3, should be 1: In scope SELECT dynamicType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.133411 [ 3863 ] {b32786e4-232e-456c-a14c-12ffc62f9251} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT e([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.134780 [ 3863 ] {b32786e4-232e-456c-a14c-12ffc62f9251} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 3, should be 0: In scope SELECT e([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.158103 [ 3863 ] {3ca7cc1c-36d0-44b6-b140-02c8b958bafd} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT editDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.159321 [ 3863 ] {3ca7cc1c-36d0-44b6-b140-02c8b958bafd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT editDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.181655 [ 3863 ] {10408154-053a-4c80-b64f-50310ea62425} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT editDistanceUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.182912 [ 3863 ] {10408154-053a-4c80-b64f-50310ea62425} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT editDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.309356 [ 3863 ] {56f6dc73-d6da-4d51-8829-10005badea30} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT empty([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.310648 [ 3863 ] {56f6dc73-d6da-4d51-8829-10005badea30} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 3, should be 1: In scope SELECT empty([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.379768 [ 3863 ] {2d073bd1-0e8c-4fa4-be9d-635fb8a59eec} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayDate([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.381026 [ 3863 ] {2d073bd1-0e8c-4fa4-be9d-635fb8a59eec} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.405547 [ 3863 ] {35bf4f43-ded8-4a92-afff-7626ccf22aa8} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.407093 [ 3863 ] {35bf4f43-ded8-4a92-afff-7626ccf22aa8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 3, should be 0: In scope SELECT emptyArrayDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.429880 [ 3863 ] {eb8aeb2b-3d8f-467d-8673-feafde2c05df} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayFloat32([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.431166 [ 3863 ] {eb8aeb2b-3d8f-467d-8673-feafde2c05df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.518242 [ 3863 ] {c5c31152-d98a-41f5-b349-d29ee28e34c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayFloat64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.519588 [ 3863 ] {c5c31152-d98a-41f5-b349-d29ee28e34c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.546839 [ 3863 ] {fd9cbde7-2b26-4c3c-9bd6-93a6e548c601} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayInt16([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.548075 [ 3863 ] {fd9cbde7-2b26-4c3c-9bd6-93a6e548c601} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.577013 [ 3863 ] {e6c8acee-9969-48db-8b37-6cda3a9e515b} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayInt32([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.578563 [ 3863 ] {e6c8acee-9969-48db-8b37-6cda3a9e515b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.605467 [ 3863 ] {ceb440ae-029e-48c7-8c6d-aab4609775be} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayInt64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.606783 [ 3863 ] {ceb440ae-029e-48c7-8c6d-aab4609775be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.633899 [ 3863 ] {58a4db3f-f52a-4222-8a42-5c9936af02f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayInt8([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.635217 [ 3863 ] {58a4db3f-f52a-4222-8a42-5c9936af02f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.662924 [ 3863 ] {4ee14531-85f7-4d0a-9e63-b35db6eaeec1} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayString([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.664259 [ 3863 ] {4ee14531-85f7-4d0a-9e63-b35db6eaeec1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 3, should be 0: In scope SELECT emptyArrayString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.691908 [ 3863 ] {f12ff139-7245-42c1-a86b-737b9b4d7237} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayToSingle([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.693296 [ 3863 ] {f12ff139-7245-42c1-a86b-737b9b4d7237} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 3, should be 1: In scope SELECT emptyArrayToSingle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.740252 [ 3863 ] {b24df5c1-29bf-4e8a-98f1-0f050fbb1a88} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayUInt16([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.741462 [ 3863 ] {b24df5c1-29bf-4e8a-98f1-0f050fbb1a88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.765421 [ 3863 ] {03b8de29-8ae1-465f-a0fc-274e3c011e98} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayUInt32([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.767090 [ 3863 ] {03b8de29-8ae1-465f-a0fc-274e3c011e98} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.879723 [ 3863 ] {093fbf2c-72cc-427e-8d4a-aa8d25077e8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayUInt64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.881033 [ 3863 ] {093fbf2c-72cc-427e-8d4a-aa8d25077e8c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:49.906834 [ 3863 ] {be17c6d4-e25b-41d9-bdd4-e8979674ceb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT emptyArrayUInt8([NULL], [NULL], [NULL]);) 2025.03.31 19:00:49.907983 [ 3863 ] {be17c6d4-e25b-41d9-bdd4-e8979674ceb0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 3, should be 0: In scope SELECT emptyArrayUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.007566 [ 3863 ] {b6b610d4-1b91-46c9-94e1-1b8271288a3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT enabledProfiles([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.009014 [ 3863 ] {b6b610d4-1b91-46c9-94e1-1b8271288a3b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 3, should be 0: In scope SELECT enabledProfiles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.033857 [ 3863 ] {0435beca-0f17-4c55-b96f-9f950604c075} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT enabledRoles([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.035234 [ 3863 ] {0435beca-0f17-4c55-b96f-9f950604c075} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 3, should be 0: In scope SELECT enabledRoles([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.059664 [ 3863 ] {58a4b6a8-e9fc-4314-9df2-3b96eb9a6c25} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT encodeURLComponent([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.060878 [ 3863 ] {58a4b6a8-e9fc-4314-9df2-3b96eb9a6c25} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.083878 [ 3863 ] {169637cf-9d5b-4371-bc11-936431018806} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT encodeURLFormComponent([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.085172 [ 3863 ] {169637cf-9d5b-4371-bc11-936431018806} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 3, should be 1: In scope SELECT encodeURLFormComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.108159 [ 3863 ] {29fc98a5-4ab9-42e1-973e-9f03cac76d58} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT encodeXMLComponent([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.109231 [ 3863 ] {29fc98a5-4ab9-42e1-973e-9f03cac76d58} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 3, should be 1: In scope SELECT encodeXMLComponent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.134059 [ 3863 ] {9d9c75dd-eeb9-427f-a028-bfc371c4cbd2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: Array(Nullable(Nothing)): In scope SELECT encrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT encrypt([NULL], '[HIDDEN]')) 2025.03.31 19:00:50.135238 [ 3863 ] {9d9c75dd-eeb9-427f-a028-bfc371c4cbd2} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'encrypt'. Expected: encryption mode string, got: Array(Nullable(Nothing)): In scope SELECT encrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:50.324085 [ 3863 ] {fb50f1de-2995-4a02-a17a-6b7e12e39059} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT endsWith([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.333543 [ 3863 ] {fb50f1de-2995-4a02-a17a-6b7e12e39059} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 3, should be 2: In scope SELECT endsWith([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.356689 [ 3863 ] {4ace805d-617c-493d-80b5-bd83578cb8ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT endsWithUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.357915 [ 3863 ] {4ace805d-617c-493d-80b5-bd83578cb8ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT endsWithUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.392612 [ 3863 ] {da692008-cd8a-40b3-9c7f-59a38e7b3d31} 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.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT entropy([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.394497 [ 3863 ] {da692008-cd8a-40b3-9c7f-59a38e7b3d31} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:00:50.427884 [ 3863 ] {1e51d5d5-11ce-460a-be52-765f0d55cf74} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT equals([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.429003 [ 3863 ] {1e51d5d5-11ce-460a-be52-765f0d55cf74} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 3, should be 2: In scope SELECT equals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.451724 [ 3863 ] {d9fc43ec-086d-4780-9221-c44d3f46a4e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT erf([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.452873 [ 3863 ] {d9fc43ec-086d-4780-9221-c44d3f46a4e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 3, should be 1: In scope SELECT erf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.546801 [ 3863 ] {76aa43e7-32cc-4fce-a4df-21635cc80b08} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT erfc([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.548241 [ 3863 ] {76aa43e7-32cc-4fce-a4df-21635cc80b08} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 3, should be 1: In scope SELECT erfc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.574979 [ 3863 ] {9c953313-d8e7-4233-896d-723523d8f780} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT errorCodeToName([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.576356 [ 3863 ] {9c953313-d8e7-4233-896d-723523d8f780} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 3, should be 1: In scope SELECT errorCodeToName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.599761 [ 3863 ] {d52195b4-df8b-4ea6-be9c-b915dd1f6b2a} executeQuery: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT evalMLMethod([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.601111 [ 3863 ] {d52195b4-df8b-4ea6-be9c-b915dd1f6b2a} TCPHandler: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:50.623195 [ 3863 ] {834d249e-97fc-40c7-bc67-6d6146f2d8c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT exp([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.624307 [ 3863 ] {834d249e-97fc-40c7-bc67-6d6146f2d8c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 3, should be 1: In scope SELECT exp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.647176 [ 3863 ] {3fd58098-61b9-4031-aafb-8b946fa1dcb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT exp10([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.648459 [ 3863 ] {3fd58098-61b9-4031-aafb-8b946fa1dcb5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 3, should be 1: In scope SELECT exp10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.671378 [ 3863 ] {6b3d78ae-71f3-4597-a588-e0f52fb85d44} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT exp2([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.672615 [ 3863 ] {6b3d78ae-71f3-4597-a588-e0f52fb85d44} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 3, should be 1: In scope SELECT exp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.782017 [ 3863 ] {45a27aae-dfa1-4ede-b4bd-d26af62878ec} executeQuery: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT exponentialMovingAverage([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.783416 [ 3863 ] {45a27aae-dfa1-4ede-b4bd-d26af62878ec} TCPHandler: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.806340 [ 3863 ] {0f9c0161-285c-4e8f-9ebc-1f8d9d73a167} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT exponentialTimeDecayedAvg([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.807487 [ 3863 ] {0f9c0161-285c-4e8f-9ebc-1f8d9d73a167} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.829139 [ 3863 ] {28faaca0-2795-47e9-96fe-612c9defcb83} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT exponentialTimeDecayedCount([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.830426 [ 3863 ] {28faaca0-2795-47e9-96fe-612c9defcb83} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.852448 [ 3863 ] {8d237855-742c-4e2c-aecb-e6a4521f0eeb} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT exponentialTimeDecayedMax([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.853727 [ 3863 ] {8d237855-742c-4e2c-aecb-e6a4521f0eeb} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.875846 [ 3863 ] {5feff521-7480-4c77-991c-6a5014397ba2} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT exponentialTimeDecayedSum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.877012 [ 3863 ] {5feff521-7480-4c77-991c-6a5014397ba2} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:50.899371 [ 3863 ] {7fd56f0e-8f86-4562-9f5e-6bf597d37d24} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extract([NULL], [NULL], [NULL]);) 2025.03.31 19:00:50.900543 [ 3863 ] {7fd56f0e-8f86-4562-9f5e-6bf597d37d24} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 3, should be 2: In scope SELECT extract([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.103879 [ 3863 ] {1a8f06b9-80b1-4c92-9079-68c33b823776} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extractAll([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.105367 [ 3863 ] {1a8f06b9-80b1-4c92-9079-68c33b823776} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 3, should be 2: In scope SELECT extractAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.132716 [ 3863 ] {80d67d9f-6b38-4c98-bff1-de73afc4b02c} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extractAllGroups([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.134276 [ 3863 ] {80d67d9f-6b38-4c98-bff1-de73afc4b02c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroups([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.156629 [ 3863 ] {6bb6a4da-7cd3-4213-9187-d8fc460b83c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extractAllGroupsHorizontal([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.158319 [ 3863 ] {6bb6a4da-7cd3-4213-9187-d8fc460b83c8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsHorizontal([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.254251 [ 3863 ] {5991305d-b27e-47cf-8463-88f7ca5bfe84} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extractAllGroupsVertical([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.255768 [ 3863 ] {5991305d-b27e-47cf-8463-88f7ca5bfe84} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 3, should be 2: In scope SELECT extractAllGroupsVertical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.282512 [ 3863 ] {a9c9ba61-cf32-49ae-b37b-20355a29fcf3} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extractGroups([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.284089 [ 3863 ] {a9c9ba61-cf32-49ae-b37b-20355a29fcf3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 3, should be 2: In scope SELECT extractGroups([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.307264 [ 3863 ] {26500cee-07a3-4ccf-9026-2e0a1a3d9506} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extractKeyValuePairs([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.308419 [ 3863 ] {26500cee-07a3-4ccf-9026-2e0a1a3d9506} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:51.351741 [ 3863 ] {623f677f-ab32-445b-be00-3531acd267b4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extractKeyValuePairsWithEscaping([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.353034 [ 3863 ] {623f677f-ab32-445b-be00-3531acd267b4} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:51.374431 [ 3863 ] {62a9f65b-d4e0-4996-87f2-d3ab2008f2f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extractTextFromHTML([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.375563 [ 3863 ] {62a9f65b-d4e0-4996-87f2-d3ab2008f2f2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 3, should be 1: In scope SELECT extractTextFromHTML([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.405845 [ 3863 ] {cb70f82a-f66a-47a4-a566-b2582628be18} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extractURLParameter([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.406980 [ 3863 ] {cb70f82a-f66a-47a4-a566-b2582628be18} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 3, should be 2: In scope SELECT extractURLParameter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.473517 [ 2854 ] {ef04cc57-830b-48e8-93f0-3312195c763b} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57178) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000034e64a6d 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000034e6765a 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6582c 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6644d 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*) @ 0x00000000358988ad 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:00:51.475153 [ 2854 ] {ef04cc57-830b-48e8-93f0-3312195c763b} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000034e64a6d 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000034e6765a 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6582c 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6644d 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*) @ 0x00000000358988ad 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:00:51.498215 [ 3863 ] {60e68718-a6cc-4a53-b998-a103ddb36448} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extractURLParameterNames([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.499417 [ 3863 ] {60e68718-a6cc-4a53-b998-a103ddb36448} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 3, should be 1: In scope SELECT extractURLParameterNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.526204 [ 3863 ] {a4273b6c-4404-4728-ba7b-c0c19e1f3680} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT extractURLParameters([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.527436 [ 3863 ] {a4273b6c-4404-4728-ba7b-c0c19e1f3680} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 3, should be 1: In scope SELECT extractURLParameters([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.627933 [ 3863 ] {ee6b7d4e-6271-4b22-a5cb-a8ed109f5be1} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT factorial([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.629405 [ 3863 ] {ee6b7d4e-6271-4b22-a5cb-a8ed109f5be1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 3, should be 1: In scope SELECT factorial([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.657905 [ 3863 ] {999011b7-d719-40b4-a449-8b724c45f9d9} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT farmFingerprint64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT farmFingerprint64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.659301 [ 3863 ] {999011b7-d719-40b4-a449-8b724c45f9d9} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT farmFingerprint64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:00:51.769554 [ 3863 ] {72ed3042-25dc-464c-a385-6b23e24ca227} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT farmHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT farmHash64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.771124 [ 3863 ] {72ed3042-25dc-464c-a385-6b23e24ca227} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT farmHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:00:51.798972 [ 3863 ] {031d787a-f151-47a8-82da-720c858d221f} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT file([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.800125 [ 3863 ] {031d787a-f151-47a8-82da-720c858d221f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 3, should be 1 or 2: In scope SELECT file([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.825902 [ 3863 ] {57ad655f-b300-4ece-8fc5-5887137c7e1c} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemAvailable should be 0 or 1: In scope SELECT filesystemAvailable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT filesystemAvailable([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.827301 [ 3863 ] {57ad655f-b300-4ece-8fc5-5887137c7e1c} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemAvailable should be 0 or 1: In scope SELECT filesystemAvailable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.838081 [ 3830 ] {8f585911-0712-49f1-acd8-42c2dc6a5912} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57208) (comment: 00955_test_final_mark_use.sh) (in query: SELECT sum(marks) FROM system.parts WHERE table = 'mt_with_pk' AND database = 'test_3fd81rit' AND active=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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:51.840567 [ 3830 ] {8f585911-0712-49f1-acd8-42c2dc6a5912} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:00:51.851127 [ 3863 ] {9c1a82ad-3bd8-4994-a9be-65881aeabb42} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemCapacity should be 0 or 1: In scope SELECT filesystemCapacity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT filesystemCapacity([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.852251 [ 3863 ] {9c1a82ad-3bd8-4994-a9be-65881aeabb42} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemCapacity should be 0 or 1: In scope SELECT filesystemCapacity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.876821 [ 3863 ] {6dfbf72d-cd6b-4652-be79-831b43ae5208} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemUnreserved should be 0 or 1: In scope SELECT filesystemUnreserved([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT filesystemUnreserved([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.878382 [ 3863 ] {6dfbf72d-cd6b-4652-be79-831b43ae5208} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemUnreserved should be 0 or 1: In scope SELECT filesystemUnreserved([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.902579 [ 3863 ] {71f8c721-9014-4db5-a6ca-fa41547003fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT finalizeAggregation([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.904014 [ 3863 ] {71f8c721-9014-4db5-a6ca-fa41547003fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 3, should be 1: In scope SELECT finalizeAggregation([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:51.930965 [ 3863 ] {c5a2d454-c6b8-40a1-8350-01460f0dc608} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT firstLine([NULL], [NULL], [NULL]);) 2025.03.31 19:00:51.932253 [ 3863 ] {c5a2d454-c6b8-40a1-8350-01460f0dc608} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 3, should be 1: In scope SELECT firstLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.015413 [ 3863 ] {d6e8dbb3-a2b6-46a2-ae30-aadb4dd527c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT firstSignificantSubdomain([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.016618 [ 3863 ] {d6e8dbb3-a2b6-46a2-ae30-aadb4dd527c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.042868 [ 3863 ] {96ca025c-60e0-4e0b-9a14-21f076dec3f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT firstSignificantSubdomainCustom([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.044198 [ 3863 ] {96ca025c-60e0-4e0b-9a14-21f076dec3f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.067285 [ 3863 ] {8cd51492-3a5a-47df-96d6-8275145cccfc} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT firstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.068656 [ 3863 ] {8cd51492-3a5a-47df-96d6-8275145cccfc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 3, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.092031 [ 3863 ] {840ec547-9bf2-4f38-ade9-081c35453789} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT firstSignificantSubdomainRFC([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.093247 [ 3863 ] {840ec547-9bf2-4f38-ade9-081c35453789} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 3, should be 1: In scope SELECT firstSignificantSubdomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.117234 [ 3863 ] {85f15645-03d7-4a9d-abc9-8cce0ead03e9} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT first_value([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.118370 [ 3863 ] {85f15645-03d7-4a9d-abc9-8cce0ead03e9} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.140720 [ 3863 ] {d7d9bede-383c-4aa1-8c21-8d4c1ec44968} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT first_value_respect_nulls([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.142136 [ 3863 ] {d7d9bede-383c-4aa1-8c21-8d4c1ec44968} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.190204 [ 3863 ] {c4eb9e74-bebc-4840-aac8-1cc0d85e6ea9} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Array(Nullable(Nothing)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT flameGraph([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.191878 [ 3863 ] {c4eb9e74-bebc-4840-aac8-1cc0d85e6ea9} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Array(Nullable(Nothing)). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:52.276236 [ 3863 ] {b688b121-48ff-4f5d-b2fd-b6d14bbf2701} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT flatten([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.277547 [ 3863 ] {b688b121-48ff-4f5d-b2fd-b6d14bbf2701} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 3, should be 1: In scope SELECT flatten([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.302819 [ 3863 ] {8444f722-0ebb-4912-8e88-dd4875766919} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT flattenTuple([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.304510 [ 3863 ] {8444f722-0ebb-4912-8e88-dd4875766919} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 3, should be 1: In scope SELECT flattenTuple([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.327029 [ 3863 ] {04e5461f-05bc-4287-ab71-06e1b4489624} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT floor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT floor([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.328304 [ 3863 ] {04e5461f-05bc-4287-ab71-06e1b4489624} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT floor([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.353133 [ 3863 ] {2c84d979-3d1e-456f-93ad-b9ecb5aa0931} executeQuery: Code: 170. DB::Exception: Bad get: has Array, requested String: In scope SELECT format([NULL], [NULL], [NULL]). (BAD_GET) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT format([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.354506 [ 3863 ] {2c84d979-3d1e-456f-93ad-b9ecb5aa0931} TCPHandler: Code: 170. DB::Exception: Bad get: has Array, requested String: In scope SELECT format([NULL], [NULL], [NULL]). (BAD_GET) 2025.03.31 19:00:52.379124 [ 3863 ] {b0fbaa0f-7677-47c9-8b5f-de18ea734689} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.380395 [ 3863 ] {b0fbaa0f-7677-47c9-8b5f-de18ea734689} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:52.426574 [ 3863 ] {a5bf4fb8-9c64-4e27-815a-862a6546dba7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTimeInJodaSyntax. Should be a date or a date with time: In scope SELECT formatDateTimeInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatDateTimeInJodaSyntax([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.427813 [ 3863 ] {a5bf4fb8-9c64-4e27-815a-862a6546dba7} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function formatDateTimeInJodaSyntax. Should be a date or a date with time: In scope SELECT formatDateTimeInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:52.450045 [ 3863 ] {a29cd230-4d4f-4abc-afb8-b6e78e29c020} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatQuery([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.451392 [ 3863 ] {a29cd230-4d4f-4abc-afb8-b6e78e29c020} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 3, should be 1: In scope SELECT formatQuery([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.472708 [ 3863 ] {a18ab4dc-b854-4d16-ac17-4ccef656c0fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatQueryOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.474286 [ 3863 ] {a18ab4dc-b854-4d16-ac17-4ccef656c0fe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQueryOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.519440 [ 3863 ] {2ed67d1f-c290-438e-9195-0ae61e20f8e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatQuerySingleLine([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.520962 [ 3863 ] {2ed67d1f-c290-438e-9195-0ae61e20f8e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLine([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.541485 [ 3863 ] {58e18af1-01ac-4680-a7dc-dd1631d1ba82} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatQuerySingleLineOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.542648 [ 3863 ] {58e18af1-01ac-4680-a7dc-dd1631d1ba82} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 3, should be 1: In scope SELECT formatQuerySingleLineOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.564299 [ 3863 ] {c41b9bf0-300a-437d-8912-78b028f695b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatReadableDecimalSize([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.565670 [ 3863 ] {c41b9bf0-300a-437d-8912-78b028f695b9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableDecimalSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.588560 [ 3863 ] {052beb2f-6889-4e55-86e6-c209237c78dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatReadableQuantity([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.589905 [ 3863 ] {052beb2f-6889-4e55-86e6-c209237c78dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 3, should be 1: In scope SELECT formatReadableQuantity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.634075 [ 3863 ] {ffaab18a-f7c8-4f15-bcb1-618048155627} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatReadableSize([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.635421 [ 3863 ] {ffaab18a-f7c8-4f15-bcb1-618048155627} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 3, should be 1: In scope SELECT formatReadableSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.660660 [ 3863 ] {8d3afbf5-c3f2-4347-aaf9-ac2186e2711d} executeQuery: Code: 43. DB::Exception: Cannot format Array(Nullable(Nothing)) as time delta: In scope SELECT formatReadableTimeDelta([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatReadableTimeDelta([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.662088 [ 3863 ] {8d3afbf5-c3f2-4347-aaf9-ac2186e2711d} TCPHandler: Code: 43. DB::Exception: Cannot format Array(Nullable(Nothing)) as time delta: In scope SELECT formatReadableTimeDelta([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:52.684682 [ 3863 ] {854d74ad-8777-4851-b475-80f078cdd90c} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatRow([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.685909 [ 3863 ] {854d74ad-8777-4851-b475-80f078cdd90c} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:52.705854 [ 3863 ] {fb0177a4-34ba-4d11-80ed-d61fe5b77abb} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT formatRowNoNewline([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.706937 [ 3863 ] {fb0177a4-34ba-4d11-80ed-d61fe5b77abb} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:52.728286 [ 3863 ] {e5b0d0ff-30ad-44dc-96a3-b35a3884c793} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fragment([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.729281 [ 3863 ] {e5b0d0ff-30ad-44dc-96a3-b35a3884c793} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 3, should be 1: In scope SELECT fragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.824008 [ 3863 ] {c83459f0-1d95-47a3-967e-582e15187485} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fromDaysSinceYearZero([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.825274 [ 3863 ] {c83459f0-1d95-47a3-967e-582e15187485} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.885316 [ 3863 ] {b0c1c0ef-8547-4f33-9a93-7dcd4356e642} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fromDaysSinceYearZero32([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.923086 [ 3863 ] {b0c1c0ef-8547-4f33-9a93-7dcd4356e642} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 3, should be 1: In scope SELECT fromDaysSinceYearZero32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:52.948010 [ 3863 ] {179acc30-c1bb-4661-866f-fb33c8b9b9df} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fromModifiedJulianDay([NULL], [NULL], [NULL]);) 2025.03.31 19:00:52.949315 [ 3863 ] {179acc30-c1bb-4661-866f-fb33c8b9b9df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.038054 [ 3863 ] {68166d31-e970-42d9-bd42-45e2593272ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fromModifiedJulianDayOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.039409 [ 3863 ] {68166d31-e970-42d9-bd42-45e2593272ed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT fromModifiedJulianDayOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.064345 [ 3863 ] {6b80a8f9-fc3b-4a29-b4fd-8b338de69dc9} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fromUTCTimestamp([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.065993 [ 3863 ] {6b80a8f9-fc3b-4a29-b4fd-8b338de69dc9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT fromUTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.087736 [ 3863 ] {0d97074d-a858-48ae-b5ef-c81d455347d0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestamp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fromUnixTimestamp([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.089210 [ 3863 ] {0d97074d-a858-48ae-b5ef-c81d455347d0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestamp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:53.112671 [ 3863 ] {99a7a1b2-fd40-47b2-bfa4-8e3be82c9e3e} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fromUnixTimestamp64Micro([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.114115 [ 3863 ] {99a7a1b2-fd40-47b2-bfa4-8e3be82c9e3e} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.137310 [ 3863 ] {756016ca-dcac-487d-9983-073462a643a0} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fromUnixTimestamp64Milli([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.211440 [ 3863 ] {756016ca-dcac-487d-9983-073462a643a0} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.297359 [ 3863 ] {9a61b764-6447-4606-9b3a-5c9792b8fcb6} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fromUnixTimestamp64Nano([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.298899 [ 3863 ] {9a61b764-6447-4606-9b3a-5c9792b8fcb6} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.320543 [ 3863 ] {21076e9c-58dd-4593-a57a-b3e55657f7c9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestampInJodaSyntax when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestampInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fromUnixTimestampInJodaSyntax([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.321670 [ 3863 ] {21076e9c-58dd-4593-a57a-b3e55657f7c9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function fromUnixTimestampInJodaSyntax when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestampInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:53.344403 [ 3863 ] {83502e81-56fd-47f3-8815-9a5c4ddeb3c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT from_utc_timestamp([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.345632 [ 3863 ] {83502e81-56fd-47f3-8815-9a5c4ddeb3c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT from_utc_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.447840 [ 3863 ] {35852686-c292-4b9a-8e20-caf1413471c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fullHostName([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.448942 [ 3863 ] {35852686-c292-4b9a-8e20-caf1413471c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 3, should be 0: In scope SELECT fullHostName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.470998 [ 3863 ] {eb1c59a5-785f-4a75-bddb-9464526d3569} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT fuzzBits([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.472221 [ 3863 ] {eb1c59a5-785f-4a75-bddb-9464526d3569} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 3, should be 2: In scope SELECT fuzzBits([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.494398 [ 3863 ] {13f4645d-01ef-44da-8c1a-db05c05e37a7} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT gccMurmurHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT gccMurmurHash([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.495819 [ 3863 ] {13f4645d-01ef-44da-8c1a-db05c05e37a7} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT gccMurmurHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:00:53.540328 [ 3863 ] {fa00857a-e3bf-4257-827c-66900560a715} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT gcd([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.541773 [ 3863 ] {fa00857a-e3bf-4257-827c-66900560a715} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 3, should be 2: In scope SELECT gcd([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.563602 [ 3863 ] {62e49c12-2a1e-468c-9220-0d050b63897a} executeQuery: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT generateRandomStructure([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.565021 [ 3863 ] {62e49c12-2a1e-468c-9220-0d050b63897a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function generateRandomStructure doesn't match: passed 3, expected from 0 to 2: In scope SELECT generateRandomStructure([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.587372 [ 3863 ] {8a3007ac-8456-43cb-a9bb-0f483643a689} 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([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT generateSnowflakeID([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.588715 [ 3863 ] {8a3007ac-8456-43cb-a9bb-0f483643a689} 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([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.687397 [ 3863 ] {daa144cd-f78e-422b-84cc-cfaac633d4c4} executeQuery: Code: 34. DB::Exception: Number of arguments for function generateULID doesn't match: passed 3, should be 0 or 1.: In scope SELECT generateULID([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT generateULID([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.688615 [ 3863 ] {daa144cd-f78e-422b-84cc-cfaac633d4c4} TCPHandler: Code: 34. DB::Exception: Number of arguments for function generateULID doesn't match: passed 3, should be 0 or 1.: In scope SELECT generateULID([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:00:53.711185 [ 3863 ] {bff95ed1-097a-4536-91ea-c3a9189afa84} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT generateUUIDv4([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.712803 [ 3863 ] {bff95ed1-097a-4536-91ea-c3a9189afa84} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.734931 [ 3863 ] {62a82916-41ac-4a28-af7c-e2d67d69aef6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT generateUUIDv7([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.736168 [ 3863 ] {62a82916-41ac-4a28-af7c-e2d67d69aef6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 3 arguments: In scope SELECT generateUUIDv7([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.760829 [ 3863 ] {eb01f22e-a99e-4ad5-a75a-8ffa848cade3} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT geoDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.762440 [ 3863 ] {eb01f22e-a99e-4ad5-a75a-8ffa848cade3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 3, should be 4: In scope SELECT geoDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.784397 [ 3863 ] {93ede022-4611-4811-bade-9dec4dcfad84} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function geoToH3. Must be Float64: In scope SELECT geoToH3([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT geoToH3([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.786101 [ 3863 ] {93ede022-4611-4811-bade-9dec4dcfad84} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function geoToH3. Must be Float64: In scope SELECT geoToH3([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:53.806980 [ 3863 ] {bdbcc6f3-7fbf-4813-b2e2-404d931e230d} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT geoToS2([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.808262 [ 3863 ] {bdbcc6f3-7fbf-4813-b2e2-404d931e230d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 3, should be 2: In scope SELECT geoToS2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.828764 [ 3863 ] {2b411c87-638a-4ca4-a5e4-b43acafdb757} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT geohashDecode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.830073 [ 3863 ] {2b411c87-638a-4ca4-a5e4-b43acafdb757} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 3, should be 1: In scope SELECT geohashDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.851719 [ 3863 ] {9ab6954a-2e15-4192-aaa2-34f95b3796e2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'longitude' to function 'geohashEncode'. Expected: Float*, got: Array(Nullable(Nothing)): In scope SELECT geohashEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT geohashEncode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.853030 [ 3863 ] {9ab6954a-2e15-4192-aaa2-34f95b3796e2} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'longitude' to function 'geohashEncode'. Expected: Float*, got: Array(Nullable(Nothing)): In scope SELECT geohashEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:53.874218 [ 3863 ] {3799e78e-f570-40a3-b069-f8ae32fe64ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT geohashesInBox([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.875391 [ 3863 ] {3799e78e-f570-40a3-b069-f8ae32fe64ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 3, should be 5: In scope SELECT geohashesInBox([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.897395 [ 3863 ] {bc08fa18-b68f-47b5-9e3b-150523d433ca} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT getClientHTTPHeader([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.898883 [ 3863 ] {bc08fa18-b68f-47b5-9e3b-150523d433ca} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.03.31 19:00:53.921476 [ 3863 ] {b4671ff8-d3fb-4a85-a997-623c87654214} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT getMacro([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.922878 [ 3863 ] {b4671ff8-d3fb-4a85-a997-623c87654214} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 3, should be 1: In scope SELECT getMacro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.947174 [ 3863 ] {3bcf1bfe-cef5-416e-a482-91bc7d8a2d32} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT getOSKernelVersion([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.948599 [ 3863 ] {3bcf1bfe-cef5-416e-a482-91bc7d8a2d32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 3, should be 0: In scope SELECT getOSKernelVersion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.970992 [ 3863 ] {5420b3bd-7d9d-4f10-876a-ffaaba479bd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT getServerPort([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.972223 [ 3863 ] {5420b3bd-7d9d-4f10-876a-ffaaba479bd1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 3, should be 1: In scope SELECT getServerPort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:53.995668 [ 3863 ] {b38c9cca-d64f-462c-aefa-5c32fb2a5a66} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT getSetting([NULL], [NULL], [NULL]);) 2025.03.31 19:00:53.996776 [ 3863 ] {b38c9cca-d64f-462c-aefa-5c32fb2a5a66} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 3, should be 1: In scope SELECT getSetting([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.018911 [ 3863 ] {2053f94f-c357-42b6-942f-6f8b0b9aaf9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT getSizeOfEnumType([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.020251 [ 3863 ] {2053f94f-c357-42b6-942f-6f8b0b9aaf9d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 3, should be 1: In scope SELECT getSizeOfEnumType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.042775 [ 3863 ] {d5ba6884-4c25-4dd6-9cc3-79111007ad58} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT getSubcolumn([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.044080 [ 3863 ] {d5ba6884-4c25-4dd6-9cc3-79111007ad58} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 3, should be 2: In scope SELECT getSubcolumn([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.134084 [ 3863 ] {7ffabd89-cea6-4df8-8a6d-f91171d3949c} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT getTypeSerializationStreams([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.135387 [ 3863 ] {7ffabd89-cea6-4df8-8a6d-f91171d3949c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 3, should be 1: In scope SELECT getTypeSerializationStreams([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.157943 [ 3863 ] {f409b341-e8fc-45e4-8f48-320637afe595} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT globalIn([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.159198 [ 3863 ] {f409b341-e8fc-45e4-8f48-320637afe595} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.181368 [ 3863 ] {ff22dcbd-5125-45cf-8e85-4c4e436dd480} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT globalInIgnoreSet([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.182864 [ 3863 ] {ff22dcbd-5125-45cf-8e85-4c4e436dd480} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.206964 [ 3863 ] {22bbdaa6-8e20-4229-b1a9-287c8f135b68} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT globalNotIn([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.210420 [ 3863 ] {22bbdaa6-8e20-4229-b1a9-287c8f135b68} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.309541 [ 3863 ] {c66e22bf-541e-4a8f-b81c-873094f297cc} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT globalNotInIgnoreSet([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.311005 [ 3863 ] {c66e22bf-541e-4a8f-b81c-873094f297cc} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.333261 [ 3863 ] {1f4c80dc-e365-474a-a407-f216c4169a66} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT globalNotNullIn([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.334738 [ 3863 ] {1f4c80dc-e365-474a-a407-f216c4169a66} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.382110 [ 3863 ] {b6f24d96-a919-4320-9527-906059aa8e05} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT globalNotNullInIgnoreSet([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.383683 [ 3863 ] {b6f24d96-a919-4320-9527-906059aa8e05} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.425228 [ 3863 ] {6676f020-30da-4b26-a467-4679fd9ec728} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT globalNullIn([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.426565 [ 3863 ] {6676f020-30da-4b26-a467-4679fd9ec728} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.446882 [ 3863 ] {c6b4fdd1-6ac5-4217-b22c-c8efb6ae1cdc} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT globalNullInIgnoreSet([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.448110 [ 3863 ] {c6b4fdd1-6ac5-4217-b22c-c8efb6ae1cdc} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.468408 [ 3863 ] {437287ca-7e31-4104-ac63-9012f5ec5f17} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT globalVariable([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.469660 [ 3863 ] {437287ca-7e31-4104-ac63-9012f5ec5f17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 3, should be 1: In scope SELECT globalVariable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.571321 [ 3863 ] {183f9558-1332-479e-a91a-fc59a11652a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT greatCircleAngle([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.572677 [ 3863 ] {183f9558-1332-479e-a91a-fc59a11652a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 3, should be 4: In scope SELECT greatCircleAngle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.594783 [ 3863 ] {748f1e23-7142-4385-a4b6-684121566898} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT greatCircleDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.595946 [ 3863 ] {748f1e23-7142-4385-a4b6-684121566898} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 3, should be 4: In scope SELECT greatCircleDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.642848 [ 3863 ] {8bad9cf1-97b6-440e-84c8-e250068b0fb8} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT greater([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.644214 [ 3863 ] {8bad9cf1-97b6-440e-84c8-e250068b0fb8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 3, should be 2: In scope SELECT greater([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.667281 [ 3863 ] {406a9fad-e65e-4dba-bb36-ee53a8e83656} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT greaterOrEquals([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.668452 [ 3863 ] {406a9fad-e65e-4dba-bb36-ee53a8e83656} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 3, should be 2: In scope SELECT greaterOrEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.726303 [ 3863 ] {3e9add30-6f6b-41c0-94f5-855222afd737} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupArray([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.727454 [ 3863 ] {3e9add30-6f6b-41c0-94f5-855222afd737} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.752852 [ 3863 ] {387edf53-966f-4258-868d-fdaba3e6ed54} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupArrayInsertAt([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.754379 [ 3863 ] {387edf53-966f-4258-868d-fdaba3e6ed54} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.776176 [ 3863 ] {8567d396-299a-404e-b2c7-e85fdc19196b} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupArrayIntersect([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.777269 [ 3863 ] {8567d396-299a-404e-b2c7-e85fdc19196b} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.796894 [ 3863 ] {bb4029b8-eb00-41d2-b021-8b2ea5e7278f} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupArrayLast([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.798029 [ 3863 ] {bb4029b8-eb00-41d2-b021-8b2ea5e7278f} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.856982 [ 3863 ] {d3ef6a29-0857-4dcd-8bb1-0acf9ca12397} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupArrayMovingAvg([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.858401 [ 3863 ] {d3ef6a29-0857-4dcd-8bb1-0acf9ca12397} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.882986 [ 3863 ] {7262a55f-ba85-4237-94ab-8cccb7ff0914} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupArrayMovingSum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.884280 [ 3863 ] {7262a55f-ba85-4237-94ab-8cccb7ff0914} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.922178 [ 3863 ] {885dff46-6655-499f-bdef-763d8c489082} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupArraySample([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.923427 [ 3863 ] {885dff46-6655-499f-bdef-763d8c489082} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.944952 [ 3863 ] {3b7d7019-863c-4354-aa53-3297fc8d29c6} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupArraySorted([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.946361 [ 3863 ] {3b7d7019-863c-4354-aa53-3297fc8d29c6} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.967295 [ 3863 ] {128b7a8f-28ea-4c77-adcb-863e68300218} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupBitAnd([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.968571 [ 3863 ] {128b7a8f-28ea-4c77-adcb-863e68300218} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:54.989189 [ 3863 ] {b4a2ab89-355c-48c1-b89a-bb19828e55fe} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupBitOr([NULL], [NULL], [NULL]);) 2025.03.31 19:00:54.990441 [ 3863 ] {b4a2ab89-355c-48c1-b89a-bb19828e55fe} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.012161 [ 3863 ] {a208a8e7-d10e-4e5e-80e6-3c9fc33106d0} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupBitXor([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.013325 [ 3863 ] {a208a8e7-d10e-4e5e-80e6-3c9fc33106d0} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.035265 [ 3863 ] {074a1d9f-b768-40f5-b843-3ae252daf126} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupBitmap([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.036646 [ 3863 ] {074a1d9f-b768-40f5-b843-3ae252daf126} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.056684 [ 3863 ] {95ce03f1-d988-40da-8de3-d6c712be2c8b} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupBitmapAnd([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.058176 [ 3863 ] {95ce03f1-d988-40da-8de3-d6c712be2c8b} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.081453 [ 3863 ] {e3356619-cfe6-48e9-bd9b-dbf49349a5a7} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupBitmapOr([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.083251 [ 3863 ] {e3356619-cfe6-48e9-bd9b-dbf49349a5a7} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.108099 [ 3863 ] {ce314885-2291-4ab2-b601-81ece6f5e668} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupBitmapXor([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.109548 [ 3863 ] {ce314885-2291-4ab2-b601-81ece6f5e668} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.131903 [ 3863 ] {d27566bf-9899-485a-b849-e995f34395a9} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupConcat([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.133208 [ 3863 ] {d27566bf-9899-485a-b849-e995f34395a9} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.155817 [ 3863 ] {a033cae2-1018-4cfc-a25d-2aabdca24e93} executeQuery: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT groupUniqArray([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.157284 [ 3863 ] {a033cae2-1018-4cfc-a25d-2aabdca24e93} TCPHandler: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.178922 [ 3863 ] {bcaaae44-28f6-45e7-85b3-9a6dd3184718} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT group_concat([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.180078 [ 3863 ] {bcaaae44-28f6-45e7-85b3-9a6dd3184718} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.257353 [ 3863 ] {06797ca4-15b6-46d2-a779-fd4263c812b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3CellAreaM2([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.258752 [ 3863 ] {06797ca4-15b6-46d2-a779-fd4263c812b0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaM2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.292983 [ 3863 ] {6372eb3e-908e-4959-b0eb-5115625fc3d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3CellAreaRads2([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.294515 [ 3863 ] {6372eb3e-908e-4959-b0eb-5115625fc3d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 3, should be 1: In scope SELECT h3CellAreaRads2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.317304 [ 3863 ] {ba2c2fb5-4f4a-4a0c-b8fc-99784b931c17} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3Distance([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.318603 [ 3863 ] {ba2c2fb5-4f4a-4a0c-b8fc-99784b931c17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 3, should be 2: In scope SELECT h3Distance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.341413 [ 3863 ] {bf617c69-63ed-46f2-bc83-f67ed23ac7e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3EdgeAngle([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.342570 [ 3863 ] {bf617c69-63ed-46f2-bc83-f67ed23ac7e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 3, should be 1: In scope SELECT h3EdgeAngle([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.365391 [ 3863 ] {24d808b5-15de-4b73-9317-1d6a746040e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3EdgeLengthKm([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.366906 [ 3863 ] {24d808b5-15de-4b73-9317-1d6a746040e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.388414 [ 3863 ] {0c09e05c-aa8d-4068-baa8-61f1354c95c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3EdgeLengthM([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.395403 [ 3863 ] {0c09e05c-aa8d-4068-baa8-61f1354c95c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3EdgeLengthM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.415289 [ 3863 ] {e76a5780-a8a7-4ccb-8f8e-79a83a87996a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3ExactEdgeLengthKm([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.416418 [ 3863 ] {e76a5780-a8a7-4ccb-8f8e-79a83a87996a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.436318 [ 3863 ] {241321fa-6c66-42a5-b70b-6a4db313a9a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3ExactEdgeLengthM([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.437504 [ 3863 ] {241321fa-6c66-42a5-b70b-6a4db313a9a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.457940 [ 3863 ] {5c7cfbf5-96cf-45dd-8315-aa76d69282c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3ExactEdgeLengthRads([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.459180 [ 3863 ] {5c7cfbf5-96cf-45dd-8315-aa76d69282c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 3, should be 1: In scope SELECT h3ExactEdgeLengthRads([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.481628 [ 3863 ] {7410bf17-134f-462e-ac0f-e2a330fe7dfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3GetBaseCell([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.560640 [ 3863 ] {7410bf17-134f-462e-ac0f-e2a330fe7dfb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 3, should be 1: In scope SELECT h3GetBaseCell([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.641958 [ 3863 ] {e544a023-11b7-4dfe-a8e9-5dd0e86e2cc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.643338 [ 3863 ] {e544a023-11b7-4dfe-a8e9-5dd0e86e2cc5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.665502 [ 3863 ] {8d81dadf-2063-4a89-a10f-291c3d95521b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3GetFaces([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.666926 [ 3863 ] {8d81dadf-2063-4a89-a10f-291c3d95521b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 3, should be 1: In scope SELECT h3GetFaces([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.687351 [ 3863 ] {94a7c582-8f9e-4b91-a2ba-bc9a9806563b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3GetIndexesFromUnidirectionalEdge([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.688656 [ 3863 ] {94a7c582-8f9e-4b91-a2ba-bc9a9806563b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.711448 [ 3863 ] {98fd5f11-07a5-45b0-b309-2c51d0bb184c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.712759 [ 3863 ] {98fd5f11-07a5-45b0-b309-2c51d0bb184c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 3, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.734865 [ 3863 ] {9e77b413-f49f-4334-b1ce-3f04e256659f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3GetPentagonIndexes([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.736195 [ 3863 ] {9e77b413-f49f-4334-b1ce-3f04e256659f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 3, should be 1: In scope SELECT h3GetPentagonIndexes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.813936 [ 3863 ] {5ff8ca1e-99b8-4c57-9abd-fa507145654e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3GetRes0Indexes([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.815190 [ 3863 ] {5ff8ca1e-99b8-4c57-9abd-fa507145654e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 3, should be 0: In scope SELECT h3GetRes0Indexes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.837283 [ 3863 ] {b3f5a907-d13b-4510-b1e7-cfcd683fe88b} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3GetResolution([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.884693 [ 3863 ] {b3f5a907-d13b-4510-b1e7-cfcd683fe88b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 3, should be 1: In scope SELECT h3GetResolution([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.938716 [ 3863 ] {fb486125-11da-497a-a568-120be4685dfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3GetUnidirectionalEdge([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.940108 [ 3863 ] {fb486125-11da-497a-a568-120be4685dfd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 3, should be 2: In scope SELECT h3GetUnidirectionalEdge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.962642 [ 3863 ] {be072a86-99e5-4ad4-8b94-b9e7318029d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3GetUnidirectionalEdgeBoundary([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.964225 [ 3863 ] {be072a86-99e5-4ad4-8b94-b9e7318029d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:55.988679 [ 3863 ] {295390aa-9f89-4e35-830c-338f529aa2b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon([NULL], [NULL], [NULL]);) 2025.03.31 19:00:55.990195 [ 3863 ] {295390aa-9f89-4e35-830c-338f529aa2b7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 3, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.011098 [ 3863 ] {e6abce9b-584e-486b-8fda-a9a3c5d236bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3HexAreaKm2([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.012543 [ 3863 ] {e6abce9b-584e-486b-8fda-a9a3c5d236bc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaKm2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.033426 [ 3863 ] {d9f5f0a0-2557-41be-8e1f-6494ae211721} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3HexAreaM2([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.034710 [ 3863 ] {d9f5f0a0-2557-41be-8e1f-6494ae211721} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 3, should be 1: In scope SELECT h3HexAreaM2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.054222 [ 3863 ] {ba71356f-638d-4b99-a01d-2d510091ba51} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3HexRing([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.055379 [ 3863 ] {ba71356f-638d-4b99-a01d-2d510091ba51} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 3, should be 2: In scope SELECT h3HexRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.077270 [ 3863 ] {ecf023d0-0ab9-4dcd-ab98-8dfb5b2bf63a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3IndexesAreNeighbors([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.078676 [ 3863 ] {ecf023d0-0ab9-4dcd-ab98-8dfb5b2bf63a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 3, should be 2: In scope SELECT h3IndexesAreNeighbors([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.101084 [ 3863 ] {6e88c49b-ef6d-4a1d-b06a-0b51ddbc2c9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3IsPentagon([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.102575 [ 3863 ] {6e88c49b-ef6d-4a1d-b06a-0b51ddbc2c9f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 3, should be 1: In scope SELECT h3IsPentagon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.125564 [ 3863 ] {10fb5f5b-2649-497d-a9b1-fbd43975ec10} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3IsResClassIII([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.127208 [ 3863 ] {10fb5f5b-2649-497d-a9b1-fbd43975ec10} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 3, should be 1: In scope SELECT h3IsResClassIII([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.149541 [ 3863 ] {4a4abdaf-0de5-4621-bf8d-5c8ebc1ef85a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3IsValid([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.150891 [ 3863 ] {4a4abdaf-0de5-4621-bf8d-5c8ebc1ef85a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 3, should be 1: In scope SELECT h3IsValid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.171517 [ 3863 ] {56924acb-c3c0-412b-9002-c61961d7c634} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3Line([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.172673 [ 3863 ] {56924acb-c3c0-412b-9002-c61961d7c634} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 3, should be 2: In scope SELECT h3Line([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.195254 [ 3863 ] {5a81ed15-4ea1-4339-aa78-f496ad383ddd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3NumHexagons([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.196715 [ 3863 ] {5a81ed15-4ea1-4339-aa78-f496ad383ddd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 3, should be 1: In scope SELECT h3NumHexagons([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.219536 [ 3863 ] {13184046-2884-4e8b-85d9-b80b67fec8c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3PointDistKm([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.220993 [ 3863 ] {13184046-2884-4e8b-85d9-b80b67fec8c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 3, should be 4: In scope SELECT h3PointDistKm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.241801 [ 3863 ] {a88f55d2-38d2-42ec-9502-f9110e3a8586} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3PointDistM([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.243135 [ 3863 ] {a88f55d2-38d2-42ec-9502-f9110e3a8586} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 3, should be 4: In scope SELECT h3PointDistM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.333895 [ 3863 ] {dcb1d575-df32-4a11-8194-86e4d07995f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3PointDistRads([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.335512 [ 3863 ] {dcb1d575-df32-4a11-8194-86e4d07995f7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 3, should be 4: In scope SELECT h3PointDistRads([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.358690 [ 3863 ] {57270057-f7fb-4d08-81a0-49b621704c1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3ToCenterChild([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.360021 [ 3863 ] {57270057-f7fb-4d08-81a0-49b621704c1a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 3, should be 2: In scope SELECT h3ToCenterChild([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.380701 [ 3863 ] {a5e62b2e-4e56-447d-9838-eb8c1a7a148e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3ToChildren([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.382239 [ 3863 ] {a5e62b2e-4e56-447d-9838-eb8c1a7a148e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 3, should be 2: In scope SELECT h3ToChildren([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.405745 [ 3863 ] {a75efde4-986e-4354-a637-c7fd67ebbf46} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3ToGeo([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.407160 [ 3863 ] {a75efde4-986e-4354-a637-c7fd67ebbf46} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 3, should be 1: In scope SELECT h3ToGeo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.519849 [ 3863 ] {9aa28fd5-da81-4baf-902c-3534810b072a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3ToGeoBoundary([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.521341 [ 3863 ] {9aa28fd5-da81-4baf-902c-3534810b072a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 3, should be 1: In scope SELECT h3ToGeoBoundary([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.545473 [ 3863 ] {14915112-b0d4-4983-afce-cfb4f33c38a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3ToParent([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.546798 [ 3863 ] {14915112-b0d4-4983-afce-cfb4f33c38a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 3, should be 2: In scope SELECT h3ToParent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.571143 [ 3863 ] {178fec6a-aa97-4444-9a7f-28a90f51158e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3ToString([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.572658 [ 3863 ] {178fec6a-aa97-4444-9a7f-28a90f51158e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 3, should be 1: In scope SELECT h3ToString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.596109 [ 3863 ] {f52fcb94-3347-4b44-b98c-9677b9bf05c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3UnidirectionalEdgeIsValid([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.597298 [ 3863 ] {f52fcb94-3347-4b44-b98c-9677b9bf05c6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 3, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.620298 [ 3863 ] {b60fb072-9360-40c3-bb0e-5b036bff70b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT h3kRing([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.621702 [ 3863 ] {b60fb072-9360-40c3-bb0e-5b036bff70b6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 3, should be 2: In scope SELECT h3kRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.644943 [ 3863 ] {dd3f60b1-23a2-4e3c-90f9-6f1651a199f8} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT halfMD5([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT halfMD5([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.646473 [ 3863 ] {dd3f60b1-23a2-4e3c-90f9-6f1651a199f8} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT halfMD5([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:00:56.667924 [ 3863 ] {fa878730-455e-460b-979e-91a1760d6b0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT has([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.669416 [ 3863 ] {fa878730-455e-460b-979e-91a1760d6b0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 3, should be 2: In scope SELECT has([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.691929 [ 3863 ] {39f4082e-a101-47a0-a9c7-8d34d68e3463} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasAll([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.693781 [ 3863 ] {39f4082e-a101-47a0-a9c7-8d34d68e3463} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 3, should be 2: In scope SELECT hasAll([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.716248 [ 3863 ] {879e59f3-36ae-4673-aa99-76b59108b9c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasAny([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.717644 [ 3863 ] {879e59f3-36ae-4673-aa99-76b59108b9c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 3, should be 2: In scope SELECT hasAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.723205 [ 3596 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7b93f28a-4c9d-4e36-add9-0e92a5ccdc5c::202503_1_36_7}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:56.740446 [ 3863 ] {05fdc8ce-0eae-4ad8-adb3-a192fbcc6963} executeQuery: Code: 43. DB::Exception: First argument for function hasColumnInTable must be const String.: In scope SELECT hasColumnInTable([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasColumnInTable([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.742129 [ 3863 ] {05fdc8ce-0eae-4ad8-adb3-a192fbcc6963} TCPHandler: Code: 43. DB::Exception: First argument for function hasColumnInTable must be const String.: In scope SELECT hasColumnInTable([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:56.763646 [ 3863 ] {d12b9301-195b-499c-be91-6f364374268b} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasSubsequence([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.764983 [ 3863 ] {d12b9301-195b-499c-be91-6f364374268b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 3, should be 2: In scope SELECT hasSubsequence([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.785388 [ 3863 ] {5114a0a5-98b6-469e-9f1d-3c59bc174b20} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasSubsequenceCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.786743 [ 3863 ] {5114a0a5-98b6-469e-9f1d-3c59bc174b20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.881906 [ 3863 ] {13f09dfa-715b-487f-8f06-d4c901198582} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.883321 [ 3863 ] {13f09dfa-715b-487f-8f06-d4c901198582} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:56.904281 [ 3863 ] {bd7fb886-b18e-48ef-80ab-7461c9c6bf37} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasSubsequenceUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:00:56.996972 [ 3831 ] {ff5ab9e3-6fc5-4ec5-b7de-a5f8d18d2d99} executeQuery: Code: 36. DB::Exception: The value of the second argument of function kostikConsistentHash (number of buckets) must not be greater than 32768: In scope SELECT kostikConsistentHash(-1, 40000). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57350) (comment: 00979_yandex_consistent_hash_fpe.sql) (in query: SELECT kostikConsistentHash(-1, 40000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001236d94d 4. unsigned short DB::FunctionConsistentHashImpl::checkBucketsRange(unsigned long) const @ 0x00000000140b2946 5. DB::FunctionConsistentHashImpl::executeConstBuckets(std::vector> const&) const @ 0x00000000140b1572 6. DB::FunctionConsistentHashImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000140affd2 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 2025.03.31 19:00:56.998073 [ 3831 ] {ff5ab9e3-6fc5-4ec5-b7de-a5f8d18d2d99} TCPHandler: Code: 36. DB::Exception: The value of the second argument of function kostikConsistentHash (number of buckets) must not be greater than 32768: In scope SELECT kostikConsistentHash(-1, 40000). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int const&) @ 0x000000001236d94d 4. unsigned short DB::FunctionConsistentHashImpl::checkBucketsRange(unsigned long) const @ 0x00000000140b2946 5. DB::FunctionConsistentHashImpl::executeConstBuckets(std::vector> const&) const @ 0x00000000140b1572 6. DB::FunctionConsistentHashImpl::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000140affd2 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 2025.03.31 19:00:56.905688 [ 3863 ] {bd7fb886-b18e-48ef-80ab-7461c9c6bf37} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 3, should be 2: In scope SELECT hasSubsequenceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.025129 [ 3863 ] {28643e4b-78a5-432c-b362-d653b57a81bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasSubstr([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.034153 [ 3863 ] {28643e4b-78a5-432c-b362-d653b57a81bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 3, should be 2: In scope SELECT hasSubstr([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.054977 [ 3863 ] {be4a1b2c-d3fd-4d41-9cc4-292ab1f34f42} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasThreadFuzzer([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.056281 [ 3863 ] {be4a1b2c-d3fd-4d41-9cc4-292ab1f34f42} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 3, should be 0: In scope SELECT hasThreadFuzzer([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.076788 [ 3863 ] {18db84fc-9ff7-4ec4-ae38-0caea0b95083} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasToken([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.077995 [ 3863 ] {18db84fc-9ff7-4ec4-ae38-0caea0b95083} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 3, should be 2: In scope SELECT hasToken([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.099719 [ 3863 ] {1b0b2936-fd4c-449b-8f18-1205b8d368c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasTokenCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.101229 [ 3863 ] {1b0b2936-fd4c-449b-8f18-1205b8d368c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.124561 [ 3863 ] {c8d3a0d0-92ac-41ea-a24d-4bea2807c643} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasTokenCaseInsensitiveOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.126331 [ 3863 ] {c8d3a0d0-92ac-41ea-a24d-4bea2807c643} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.148776 [ 3863 ] {092f4cd2-a4cc-4f8f-876e-2cfb845087b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hasTokenOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.150276 [ 3863 ] {092f4cd2-a4cc-4f8f-876e-2cfb845087b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 3, should be 2: In scope SELECT hasTokenOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.171343 [ 3863 ] {289ce98c-d987-4007-8213-134aed73ffad} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hex([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.172583 [ 3863 ] {289ce98c-d987-4007-8213-134aed73ffad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 3, should be 1: In scope SELECT hex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.232889 [ 3863 ] {72a7a952-42c7-4397-9304-7b751270e9a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hilbertDecode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.235212 [ 3863 ] {72a7a952-42c7-4397-9304-7b751270e9a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 3, should be 2: In scope SELECT hilbertDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.254060 [ 3863 ] {a784c4cc-ff24-4681-8988-bbf32da7fe7f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hilbertEncode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.255266 [ 3863 ] {a784c4cc-ff24-4681-8988-bbf32da7fe7f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:57.359026 [ 3863 ] {70eb8808-865b-4844-94ca-3e11268a1f27} executeQuery: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT histogram([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.360229 [ 3863 ] {70eb8808-865b-4844-94ca-3e11268a1f27} TCPHandler: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.381422 [ 3863 ] {234615a5-2a53-4697-aea8-1158c8fb86b6} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT hiveHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hiveHash([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.382760 [ 3863 ] {234615a5-2a53-4697-aea8-1158c8fb86b6} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT hiveHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:00:57.404215 [ 3863 ] {83c90c07-07b6-4588-a63c-b6a947dcae37} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hop. Should be a date with time: In scope SELECT hop([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hop([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.405580 [ 3863 ] {83c90c07-07b6-4588-a63c-b6a947dcae37} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hop. Should be a date with time: In scope SELECT hop([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:57.427203 [ 3863 ] {c00807be-0132-41de-ad21-0078f99c1c1b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hopEnd. Should be a date with time: In scope SELECT hopEnd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hopEnd([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.428392 [ 3863 ] {c00807be-0132-41de-ad21-0078f99c1c1b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hopEnd. Should be a date with time: In scope SELECT hopEnd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:57.519795 [ 3863 ] {a23547fa-1fb5-401a-a75a-8adec8b86a13} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hopStart. Should be a date with time: In scope SELECT hopStart([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hopStart([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.521066 [ 3863 ] {a23547fa-1fb5-401a-a75a-8adec8b86a13} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function hopStart. Should be a date with time: In scope SELECT hopStart([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:57.543701 [ 3863 ] {2ce5c5ab-b203-45c0-985c-5e4d6e07357d} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hostName([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.544915 [ 3863 ] {2ce5c5ab-b203-45c0-985c-5e4d6e07357d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.565377 [ 3863 ] {f71d7ab3-8a82-4d80-926b-2710134d0534} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hostname([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.566653 [ 3863 ] {f71d7ab3-8a82-4d80-926b-2710134d0534} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 3, should be 0: In scope SELECT hostname([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.588947 [ 3863 ] {2fdb3d47-7d00-4769-9360-bfc307db12ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT hypot([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.590458 [ 3863 ] {2fdb3d47-7d00-4769-9360-bfc307db12ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 3, should be 2: In scope SELECT hypot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.611831 [ 3863 ] {6a256813-37a1-45f1-865d-8f352bb55ef8} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT identity([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.613247 [ 3863 ] {6a256813-37a1-45f1-865d-8f352bb55ef8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 3, should be 1: In scope SELECT identity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.633988 [ 3863 ] {6de4da10-800c-47a1-bc14-67d2edc7b837} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT idnaDecode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.635315 [ 3863 ] {6de4da10-800c-47a1-bc14-67d2edc7b837} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 3, should be 1: In scope SELECT idnaDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.655852 [ 3863 ] {6cee4f0a-7c2a-4760-a17f-f3a85ecb7cf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT idnaEncode([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.657184 [ 3863 ] {6cee4f0a-7c2a-4760-a17f-f3a85ecb7cf8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 3, should be 1: In scope SELECT idnaEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.678502 [ 3863 ] {94ab2c83-4064-4d17-811d-128d21a5b829} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument (condition) of function if. Must be UInt8.: In scope SELECT if([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT if([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.679808 [ 3863 ] {94ab2c83-4064-4d17-811d-128d21a5b829} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument (condition) of function if. Must be UInt8.: In scope SELECT if([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:57.701665 [ 3863 ] {8685d2f8-df4c-45cd-b8f3-62734d07afa8} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ifNotFinite([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.703085 [ 3863 ] {8685d2f8-df4c-45cd-b8f3-62734d07afa8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 3, should be 2: In scope SELECT ifNotFinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.726840 [ 3863 ] {cb8c4e07-dfca-4083-9264-0c57c40f643d} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ifNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.739072 [ 3863 ] {cb8c4e07-dfca-4083-9264-0c57c40f643d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 3, should be 2: In scope SELECT ifNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.795748 [ 3863 ] {d9e7a35e-f522-418b-9248-da07de24037a} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ilike([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.797444 [ 3863 ] {d9e7a35e-f522-418b-9248-da07de24037a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 3, should be 2: In scope SELECT ilike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.866156 [ 3863 ] {7b2227ed-ad3a-42e6-80ea-cd97007db119} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT in([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.867444 [ 3863 ] {7b2227ed-ad3a-42e6-80ea-cd97007db119} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.888710 [ 3863 ] {77a535ba-9775-4028-b8f9-448fb2e14232} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT inIgnoreSet([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.890065 [ 3863 ] {77a535ba-9775-4028-b8f9-448fb2e14232} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:57.997106 [ 3863 ] {4f2ad529-c878-4be1-852d-1c20935af90e} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT indexOf([NULL], [NULL], [NULL]);) 2025.03.31 19:00:57.998399 [ 3863 ] {4f2ad529-c878-4be1-852d-1c20935af90e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 3, should be 2: In scope SELECT indexOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.018448 [ 3863 ] {f3c78f80-0e00-4322-9690-99d2c8739a00} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT initcap([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.019698 [ 3863 ] {f3c78f80-0e00-4322-9690-99d2c8739a00} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 3, should be 1: In scope SELECT initcap([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.041646 [ 3863 ] {5ca4064b-da23-46d5-b62e-603d7a8fc4a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT initcapUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.043188 [ 3863 ] {5ca4064b-da23-46d5-b62e-603d7a8fc4a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 3, should be 1: In scope SELECT initcapUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.062757 [ 3863 ] {3dc75708-2cec-45f9-a50e-85700e70c4e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT initialQueryID([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.063917 [ 3863 ] {3dc75708-2cec-45f9-a50e-85700e70c4e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initialQueryID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.084562 [ 3863 ] {77538086-999d-4e5c-af9e-c26909ea2f54} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT initial_query_id([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.086003 [ 3863 ] {77538086-999d-4e5c-af9e-c26909ea2f54} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 3, should be 0: In scope SELECT initial_query_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.106845 [ 3863 ] {b64dc83d-255f-4da7-8f6d-d335de641a04} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT initializeAggregation([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.107974 [ 3863 ] {b64dc83d-255f-4da7-8f6d-d335de641a04} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:58.125453 [ 3863 ] {e6c26e55-991e-4b77-932b-f720cdbb90da} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitive: In scope SELECT instr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT instr([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.126401 [ 3863 ] {e6c26e55-991e-4b77-932b-f720cdbb90da} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitive: In scope SELECT instr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:58.144683 [ 3863 ] {479bc6f6-4b3c-40ab-871a-22da5ee0c6df} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT intDiv([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.145644 [ 3863 ] {479bc6f6-4b3c-40ab-871a-22da5ee0c6df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 3, should be 2: In scope SELECT intDiv([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.165506 [ 3863 ] {e42d1f1e-5c80-4a0f-b635-980e0dfb2591} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT intDivOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.167106 [ 3863 ] {e42d1f1e-5c80-4a0f-b635-980e0dfb2591} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 3, should be 2: In scope SELECT intDivOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.188083 [ 3863 ] {c6383c29-eaca-44ca-a99e-e48a55b95bc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT intExp10([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.189576 [ 3863 ] {c6383c29-eaca-44ca-a99e-e48a55b95bc0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 3, should be 1: In scope SELECT intExp10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.209623 [ 3863 ] {9a22254b-ffe6-40fd-b93b-302e977c9795} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT intExp2([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.211147 [ 3863 ] {9a22254b-ffe6-40fd-b93b-302e977c9795} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 3, should be 1: In scope SELECT intExp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.230657 [ 3863 ] {d8962325-5f36-44c2-95ac-07724f797025} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT intHash32([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.231860 [ 3863 ] {d8962325-5f36-44c2-95ac-07724f797025} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 3, should be 1: In scope SELECT intHash32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.259052 [ 3863 ] {f635084c-5cdd-4a0c-91ac-486590b1c6f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT intHash64([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.260570 [ 3863 ] {f635084c-5cdd-4a0c-91ac-486590b1c6f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 3, should be 1: In scope SELECT intHash64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.281227 [ 3863 ] {ec24179e-9233-412f-ba17-28a1da7b63ec} executeQuery: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT intervalLengthSum([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.282942 [ 3863 ] {ec24179e-9233-412f-ba17-28a1da7b63ec} TCPHandler: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.301814 [ 3863 ] {7ac74ed3-69ec-4745-944b-1f1438df4ee7} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isConstant([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.304094 [ 3863 ] {7ac74ed3-69ec-4745-944b-1f1438df4ee7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 3, should be 1: In scope SELECT isConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.328255 [ 3863 ] {c7735289-02d9-4b8b-9488-abc4dd70fdef} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 3, should be 1 or 2.: In scope SELECT isDecimalOverflow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isDecimalOverflow([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.329967 [ 3863 ] {c7735289-02d9-4b8b-9488-abc4dd70fdef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 3, should be 1 or 2.: In scope SELECT isDecimalOverflow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.350731 [ 3863 ] {5c4f2f1b-4a1d-43c1-a6be-a10da4e4d91a} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isDynamicElementInSharedData([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.352141 [ 3863 ] {5c4f2f1b-4a1d-43c1-a6be-a10da4e4d91a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 3, should be 1: In scope SELECT isDynamicElementInSharedData([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.373369 [ 3863 ] {8be554b7-bc7b-4ef4-a46a-463c5127de95} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isFinite([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.374827 [ 3863 ] {8be554b7-bc7b-4ef4-a46a-463c5127de95} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 3, should be 1: In scope SELECT isFinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.396434 [ 3863 ] {2fe3bc5e-5ac0-4322-b7a7-22147f667ce0} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isIPAddressInRange([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.397778 [ 3863 ] {2fe3bc5e-5ac0-4322-b7a7-22147f667ce0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 3, should be 2: In scope SELECT isIPAddressInRange([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.418926 [ 3863 ] {1aa78903-77fd-4247-9bd9-1b6b04253044} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isIPv4String([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.420398 [ 3863 ] {1aa78903-77fd-4247-9bd9-1b6b04253044} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 3, should be 1: In scope SELECT isIPv4String([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.513298 [ 3863 ] {82ee2584-1028-41e2-b89c-3fb1e985dd0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isIPv6String([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.514694 [ 3863 ] {82ee2584-1028-41e2-b89c-3fb1e985dd0d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 3, should be 1: In scope SELECT isIPv6String([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.536390 [ 3863 ] {6370fb2f-e4fd-4676-a187-f598780d1a49} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isInfinite([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.537602 [ 3863 ] {6370fb2f-e4fd-4676-a187-f598780d1a49} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 3, should be 1: In scope SELECT isInfinite([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.559183 [ 3863 ] {32d11b5f-392a-40eb-b390-581e9f827d15} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isNaN([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.560462 [ 3863 ] {32d11b5f-392a-40eb-b390-581e9f827d15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 3, should be 1: In scope SELECT isNaN([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.581915 [ 3863 ] {26ce8372-cd71-4d48-888d-55e0a7f3b5e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isNotDistinctFrom([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.583091 [ 3863 ] {26ce8372-cd71-4d48-888d-55e0a7f3b5e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 3, should be 2: In scope SELECT isNotDistinctFrom([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.605156 [ 3863 ] {4cba57b0-4e74-4271-98c5-a725f619ee1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isNotNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.606677 [ 3863 ] {4cba57b0-4e74-4271-98c5-a725f619ee1b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 3, should be 1: In scope SELECT isNotNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.629014 [ 3863 ] {5bdae0bf-eb06-4659-a781-f1c8c74872c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.630572 [ 3863 ] {5bdae0bf-eb06-4659-a781-f1c8c74872c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 3, should be 1: In scope SELECT isNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.650136 [ 3863 ] {2fcec543-a08b-40fe-ab7b-08e240a1db6e} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isNullable([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.651383 [ 3863 ] {2fcec543-a08b-40fe-ab7b-08e240a1db6e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 3, should be 1: In scope SELECT isNullable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.771181 [ 3863 ] {872c9939-2978-4723-81bf-262579a4e4cc} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isValidJSON([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.772621 [ 3863 ] {872c9939-2978-4723-81bf-262579a4e4cc} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.795580 [ 3863 ] {c319d6fe-5cf2-42f8-8700-af4162f1f15f} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isValidUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.797025 [ 3863 ] {c319d6fe-5cf2-42f8-8700-af4162f1f15f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT isValidUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.819370 [ 3863 ] {76763059-ac78-4ef0-9a89-f8da4de495a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT isZeroOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.820710 [ 3863 ] {76763059-ac78-4ef0-9a89-f8da4de495a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 3, should be 1: In scope SELECT isZeroOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.879794 [ 3863 ] {b861a7e6-8c04-40a5-9658-fc0f34b005ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT jaroSimilarity([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.881354 [ 3863 ] {b861a7e6-8c04-40a5-9658-fc0f34b005ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroSimilarity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:58.906973 [ 3863 ] {41076a51-53e6-41e7-991b-19690b4a9c0d} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT jaroWinklerSimilarity([NULL], [NULL], [NULL]);) 2025.03.31 19:00:58.908404 [ 3863 ] {41076a51-53e6-41e7-991b-19690b4a9c0d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 3, should be 2: In scope SELECT jaroWinklerSimilarity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:59.015551 [ 3863 ] {65e0d170-19bd-47e9-abe0-e3e4f0b62343} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT javaHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT javaHash([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.016904 [ 3863 ] {65e0d170-19bd-47e9-abe0-e3e4f0b62343} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT javaHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:00:59.036149 [ 3863 ] {1984f82e-a1fe-49a8-a76c-23e5516d0892} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT javaHashUTF16LE([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT javaHashUTF16LE([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.037270 [ 3863 ] {1984f82e-a1fe-49a8-a76c-23e5516d0892} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT javaHashUTF16LE([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:00:59.058425 [ 3863 ] {a34464df-2695-4147-b976-f6683c79e99d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT joinGet([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.059810 [ 3863 ] {a34464df-2695-4147-b976-f6683c79e99d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function joinGet, expected a const string.: In scope SELECT joinGet([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:59.080570 [ 3863 ] {a5c067de-42d3-4627-8872-e029c5493ebe} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT joinGetOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.081970 [ 3863 ] {a5c067de-42d3-4627-8872-e029c5493ebe} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function joinGet, expected a const string.: In scope SELECT joinGetOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:59.177022 [ 3863 ] {cb92a2b1-d491-4500-9257-33e9232dcf3b} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT jsonMergePatch([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.178654 [ 3863 ] {cb92a2b1-d491-4500-9257-33e9232dcf3b} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:00:59.200049 [ 3863 ] {1aeb8f63-7f43-4e1c-ad53-b72b6818baba} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT jumpConsistentHash([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.201459 [ 3863 ] {1aeb8f63-7f43-4e1c-ad53-b72b6818baba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 3, should be 2: In scope SELECT jumpConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:59.223915 [ 3863 ] {5c44e2c7-fc2f-4558-a418-b3e2e1ec1e91} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT kafkaMurmurHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT kafkaMurmurHash([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.225165 [ 3863 ] {5c44e2c7-fc2f-4558-a418-b3e2e1ec1e91} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT kafkaMurmurHash([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:00:59.245490 [ 3863 ] {2320d4fb-a6c0-4283-a933-2e45b3d0e4b9} executeQuery: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT kolmogorovSmirnovTest([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.246902 [ 3863 ] {2320d4fb-a6c0-4283-a933-2e45b3d0e4b9} TCPHandler: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:59.266923 [ 3863 ] {ee3e9493-2408-492f-b1ce-f79900160448} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT kostikConsistentHash([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.268123 [ 3863 ] {ee3e9493-2408-492f-b1ce-f79900160448} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT kostikConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:59.394460 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:00:59.410710 [ 3863 ] {43483781-6e52-4770-aa19-75365e2d73b0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT kql_array_sort_asc([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.412216 [ 3863 ] {43483781-6e52-4770-aa19-75365e2d73b0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=724). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:00:59.424470 [ 3922 ] {27f8a875-646a-4ae4-94e6-efc3770c607b} 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.10457.altinitytest (altinity build)) (from [::1]:37220) (comment: 01273_arrow_dictionaries_load.sh) (in query: DROP DATABASE IF EXISTS test_ah29fotm ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:00:59.426301 [ 3922 ] {27f8a875-646a-4ae4-94e6-efc3770c607b} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:00:59.526243 [ 3863 ] {396c89f6-83e2-4f67-b203-f84daf3f2f39} executeQuery: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT kurtPop([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.527371 [ 3863 ] {396c89f6-83e2-4f67-b203-f84daf3f2f39} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:59.549823 [ 3863 ] {52251aa4-e2f3-433e-b54d-82300f669928} executeQuery: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT kurtSamp([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.550971 [ 3863 ] {52251aa4-e2f3-433e-b54d-82300f669928} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:59.572879 [ 3863 ] {e8a6eecb-ff54-4a70-aa79-2630a7ce51e4} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lagInFrame([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.574141 [ 3863 ] {e8a6eecb-ff54-4a70-aa79-2630a7ce51e4} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) 2025.03.31 19:00:59.603569 [ 3863 ] {2c199b37-7a01-45fc-9565-fb8dafecdbe3} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT largestTriangleThreeBuckets([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.604738 [ 3863 ] {2c199b37-7a01-45fc-9565-fb8dafecdbe3} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:59.699289 [ 3863 ] {b8faf9ce-ba2d-4092-914a-bc1d6d7f286c} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT last_value([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.701117 [ 3863 ] {b8faf9ce-ba2d-4092-914a-bc1d6d7f286c} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:59.724757 [ 3863 ] {00e18d2a-16af-462e-a3fb-c95548e69a7e} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT last_value_respect_nulls([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.726334 [ 3863 ] {00e18d2a-16af-462e-a3fb-c95548e69a7e} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:59.748163 [ 3863 ] {1ca6aa7a-7ccc-4868-8e8a-faf101fc9969} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lcase([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.749551 [ 3863 ] {1ca6aa7a-7ccc-4868-8e8a-faf101fc9969} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lcase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:59.771760 [ 3863 ] {09e2e41d-6023-45b3-8d25-5c9d6f956e70} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lcm([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.773211 [ 3863 ] {09e2e41d-6023-45b3-8d25-5c9d6f956e70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 3, should be 2: In scope SELECT lcm([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:00:59.845149 [ 3863 ] {0b09da87-7403-423a-abd5-8800636edf55} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT leadInFrame([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.846777 [ 3863 ] {0b09da87-7403-423a-abd5-8800636edf55} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) 2025.03.31 19:00:59.899328 [ 3863 ] {c499ae5b-7776-44a4-835a-2b633697e8f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT left([NULL], [NULL], [NULL]);) 2025.03.31 19:00:59.900581 [ 3863 ] {c499ae5b-7776-44a4-835a-2b633697e8f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 3, should be 2: In scope SELECT left([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.017025 [ 3863 ] {88cbe7e1-177f-4c2a-a44e-8228c90885e0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPad, should be string: In scope SELECT leftPad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT leftPad([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.018383 [ 3863 ] {88cbe7e1-177f-4c2a-a44e-8228c90885e0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPad, should be string: In scope SELECT leftPad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:00.087217 [ 3863 ] {e2f8664e-d9bd-41d2-8b3e-f7e97e82bc90} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPadUTF8, should be string: In scope SELECT leftPadUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT leftPadUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.088642 [ 3863 ] {e2f8664e-d9bd-41d2-8b3e-f7e97e82bc90} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPadUTF8, should be string: In scope SELECT leftPadUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:00.113561 [ 3863 ] {e14adc27-3d0f-41ad-a36e-55dd4524748c} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT leftUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.114933 [ 3863 ] {e14adc27-3d0f-41ad-a36e-55dd4524748c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 3, should be 2: In scope SELECT leftUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.136549 [ 3863 ] {88199aa0-93f7-4db5-9f0d-e34f5a9ea8ff} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lemmatize([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.137956 [ 3863 ] {88199aa0-93f7-4db5-9f0d-e34f5a9ea8ff} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:01:00.150796 [ 6107 ] {2ac62b3a-0cfe-4cf8-bb61-e0327f981f47} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:9263595b-f0df-43e6-9420-486af3ed9bcd'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50284) (comment: 01825_new_type_json_11.sh) (in query: CREATE DATABASE IF NOT EXISTS test_zqtpq7ib 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.152416 [ 6107 ] {2ac62b3a-0cfe-4cf8-bb61-e0327f981f47} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:9263595b-f0df-43e6-9420-486af3ed9bcd'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.161416 [ 3863 ] {6e45393e-dde3-456f-a7b2-77855cd565da} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT length([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.162930 [ 3863 ] {6e45393e-dde3-456f-a7b2-77855cd565da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 3, should be 1: In scope SELECT length([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.165668 [ 6107 ] {cb00897e-a4f0-450a-a65b-301c596448a2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:f7319720-6c37-48af-b141-f3b5114d891e'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50308) (comment: 01358_constexpr_constraint.sql) (in query: CREATE DATABASE IF NOT EXISTS test_1k7oq6jc 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.167151 [ 6107 ] {cb00897e-a4f0-450a-a65b-301c596448a2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:f7319720-6c37-48af-b141-f3b5114d891e'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.180726 [ 6107 ] {25a731eb-070d-46fa-9321-82d334708c9a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:d819ae3e-27ed-4e8b-a57b-a60e5fb3e4e8'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50324) (comment: 00666_uniq_complex_types.sql) (in query: CREATE DATABASE IF NOT EXISTS test_88uythkk 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.182103 [ 6107 ] {25a731eb-070d-46fa-9321-82d334708c9a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:d819ae3e-27ed-4e8b-a57b-a60e5fb3e4e8'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.191153 [ 3863 ] {aca46abd-d278-474f-82de-d765c6807878} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lengthUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.192311 [ 3863 ] {aca46abd-d278-474f-82de-d765c6807878} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 3, should be 1: In scope SELECT lengthUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.195134 [ 6107 ] {5bda17d2-fe12-4873-8bd2-5d8eb225addd} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:44c7b4a7-87d1-42c4-9f6d-4d6dee8296ec'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50340) (comment: 02708_dotProduct.sql) (in query: CREATE DATABASE IF NOT EXISTS test_pgqkedb9 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.196466 [ 6107 ] {5bda17d2-fe12-4873-8bd2-5d8eb225addd} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:44c7b4a7-87d1-42c4-9f6d-4d6dee8296ec'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.210407 [ 3922 ] {f53d7f97-df3b-4a61-b113-b4a450ff9300} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:e2f0071c-8733-4dcd-9b2f-6a06e6d00266'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50342) (comment: 00804_test_delta_codec_compression.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qn3nzfh4 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.211887 [ 3922 ] {f53d7f97-df3b-4a61-b113-b4a450ff9300} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:e2f0071c-8733-4dcd-9b2f-6a06e6d00266'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.215704 [ 3863 ] {11632092-fd12-44e5-9810-9b124cb8a3e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT less([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.216831 [ 3863 ] {11632092-fd12-44e5-9810-9b124cb8a3e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 3, should be 2: In scope SELECT less([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.227703 [ 3922 ] {e4949dae-7d0f-4b68-8a5d-8b1096ae17b8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:5cbcf81d-bdb9-4b9f-afca-0a4ba138237a'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50354) (comment: 00815_left_join_on_stepanel.sql) (in query: CREATE DATABASE IF NOT EXISTS test_4h2q251q 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.229084 [ 3922 ] {e4949dae-7d0f-4b68-8a5d-8b1096ae17b8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:5cbcf81d-bdb9-4b9f-afca-0a4ba138237a'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.236846 [ 3863 ] {bd9b1ea4-36c3-47cf-84ec-a84506bd4cca} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lessOrEquals([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.238355 [ 3863 ] {bd9b1ea4-36c3-47cf-84ec-a84506bd4cca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 3, should be 2: In scope SELECT lessOrEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.242546 [ 3922 ] {74cc414b-dc0d-4e3a-af15-9d660fbeafc1} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:b2f4cbc3-3ee2-4ac6-8f09-46f256d78a18'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50358) (comment: 02265_per_table_ttl_mutation_on_change.sql) (in query: CREATE DATABASE IF NOT EXISTS test_jdu01zfq 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.243925 [ 3922 ] {74cc414b-dc0d-4e3a-af15-9d660fbeafc1} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:b2f4cbc3-3ee2-4ac6-8f09-46f256d78a18'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.259152 [ 3922 ] {876919a7-63a4-4b84-afd7-83c8d0172895} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:c93dd291-e5db-4ca0-b660-e8a59cc8b179'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50372) (comment: 01602_array_aggregation.sql) (in query: CREATE DATABASE IF NOT EXISTS test_t778cri3 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.260750 [ 3922 ] {876919a7-63a4-4b84-afd7-83c8d0172895} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:c93dd291-e5db-4ca0-b660-e8a59cc8b179'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.262177 [ 3863 ] {c5acd2d2-45a6-4e3c-b054-446cea4277c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT levenshteinDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.263846 [ 3863 ] {c5acd2d2-45a6-4e3c-b054-446cea4277c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.274999 [ 3922 ] {2e472485-777d-43dd-a681-4afca9477999} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:81d81efb-ba0f-410d-86b1-f51e658f79a3'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50384) (comment: 00800_low_cardinality_distributed_insert.sql) (in query: CREATE DATABASE IF NOT EXISTS test_12dmhbds 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.276629 [ 3922 ] {2e472485-777d-43dd-a681-4afca9477999} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:81d81efb-ba0f-410d-86b1-f51e658f79a3'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.284537 [ 3863 ] {f91f2042-7bcc-4f49-939f-f78091af48e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT levenshteinDistanceUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.286256 [ 3863 ] {f91f2042-7bcc-4f49-939f-f78091af48e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT levenshteinDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.291862 [ 3922 ] {0b53d1a1-0960-4f90-a52f-f79cb1d3abe0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:efe8acb8-e827-4d69-bf3e-67f68b7f2197'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50396) (comment: 00725_comment_columns_long.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lk0nbc1l 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.293187 [ 3922 ] {0b53d1a1-0960-4f90-a52f-f79cb1d3abe0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:efe8acb8-e827-4d69-bf3e-67f68b7f2197'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.307023 [ 3863 ] {0b655d9f-8d27-4c3d-813b-27c81ef33a39} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lgamma([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.308439 [ 3863 ] {0b655d9f-8d27-4c3d-813b-27c81ef33a39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 3, should be 1: In scope SELECT lgamma([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.309092 [ 3922 ] {810982ee-95b7-442c-ac46-106ad07edf26} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:eb2c4e52-78ee-4a0d-b845-8ed9177c2270'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50398) (comment: 00821_distributed_storage_with_join_on.sql) (in query: CREATE DATABASE IF NOT EXISTS test_mhdd6pjt 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.310949 [ 3922 ] {810982ee-95b7-442c-ac46-106ad07edf26} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:eb2c4e52-78ee-4a0d-b845-8ed9177c2270'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.326449 [ 3922 ] {1df6ccb5-29e2-4d82-8552-6c820400be1f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:2a15e4fe-bbde-4bcb-a756-8b537703e4de'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50404) (comment: 00910_buffer_prewhere.sql) (in query: CREATE DATABASE IF NOT EXISTS test_81davyp8 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.327840 [ 3922 ] {1df6ccb5-29e2-4d82-8552-6c820400be1f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:2a15e4fe-bbde-4bcb-a756-8b537703e4de'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.344713 [ 4240 ] {47dde2e3-eefd-4b7b-b757-3895f01298bc} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:ac0bafa7-4fa3-4050-accd-22ca57f0442a'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50410) (comment: 00162_shard_global_join.sql) (in query: CREATE DATABASE IF NOT EXISTS test_j1e73bby 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.347866 [ 3863 ] {04ff068b-5e4f-434b-b896-c1458bef04b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT like([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.349158 [ 3863 ] {04ff068b-5e4f-434b-b896-c1458bef04b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 3, should be 2: In scope SELECT like([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.368248 [ 4240 ] {47dde2e3-eefd-4b7b-b757-3895f01298bc} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:ac0bafa7-4fa3-4050-accd-22ca57f0442a'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.386682 [ 6194 ] {6b6ea95b-90b3-46ae-9703-692f30618b2a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:6ad3bcae-b406-4e70-bcab-45fe327c738b'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50412) (comment: 01780_column_sparse_tuple.sql) (in query: CREATE DATABASE IF NOT EXISTS test_nbbmnr3y 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.388244 [ 6194 ] {6b6ea95b-90b3-46ae-9703-692f30618b2a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:6ad3bcae-b406-4e70-bcab-45fe327c738b'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.409917 [ 3863 ] {288b22c7-1cc0-4b66-bb14-8d38bb0f453c} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ln([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.412813 [ 3863 ] {288b22c7-1cc0-4b66-bb14-8d38bb0f453c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT ln([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.431834 [ 3863 ] {8c3fa9f3-0b8e-4fc4-9350-4fb55d3a7d53} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function locate: In scope SELECT locate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT locate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.433085 [ 3863 ] {8c3fa9f3-0b8e-4fc4-9350-4fb55d3a7d53} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function locate: In scope SELECT locate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:00.453185 [ 3863 ] {6524fd5d-12e9-460c-8e58-3bf68c627f04} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT log([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.454586 [ 3863 ] {6524fd5d-12e9-460c-8e58-3bf68c627f04} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 3, should be 1: In scope SELECT log([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.473480 [ 3863 ] {111097c4-ac1e-4a21-ad09-9dc6cd9b1ab9} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT log10([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.474803 [ 3863 ] {111097c4-ac1e-4a21-ad09-9dc6cd9b1ab9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 3, should be 1: In scope SELECT log10([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.496483 [ 3863 ] {9d598cd6-982b-448b-9980-b290e9e39430} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT log1p([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.498026 [ 3863 ] {9d598cd6-982b-448b-9980-b290e9e39430} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 3, should be 1: In scope SELECT log1p([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.501044 [ 3922 ] {29248d22-a641-4d89-988c-4f268acc408b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:ddc07a1a-e569-4b46-a764-a8de8d341af0'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50420) (comment: 01196_max_parser_depth.sh) (in query: CREATE DATABASE IF NOT EXISTS test_wba9x9y2 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.502624 [ 3922 ] {29248d22-a641-4d89-988c-4f268acc408b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:ddc07a1a-e569-4b46-a764-a8de8d341af0'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.518278 [ 3922 ] {54af05e2-5f2e-426a-b4f8-39cc53b8d683} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:8d0fe81f-b28c-409b-9c4a-542eaff7eb9c'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50448) (comment: 03000_virtual_columns_in_prewhere.sql) (in query: CREATE DATABASE IF NOT EXISTS test_5m8wdgpb 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.519243 [ 3863 ] {ce2d8a8a-9d3e-4e87-a865-e3fcec47f19f} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT log2([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.519607 [ 3922 ] {54af05e2-5f2e-426a-b4f8-39cc53b8d683} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:8d0fe81f-b28c-409b-9c4a-542eaff7eb9c'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.520413 [ 3863 ] {ce2d8a8a-9d3e-4e87-a865-e3fcec47f19f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 3, should be 1: In scope SELECT log2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.533393 [ 3922 ] {76211045-c192-4cdf-9c89-6d5aab730787} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:0bac71f2-46f1-4b38-bc11-0f9f1af5b788'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50454) (comment: 03146_parameterized_view_with_date.sql) (in query: CREATE DATABASE IF NOT EXISTS test_t4jwp530 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:00.534897 [ 3922 ] {76211045-c192-4cdf-9c89-6d5aab730787} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '970f2956c7dc:9000:a12060a7-97d2-4680-a0aa-f80faa41a79b', current host ID: '970f2956c7dc:9000:0bac71f2-46f1-4b38-bc11-0f9f1af5b788'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&) @ 0x0000000032a92267 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000032a0d174 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000032a1db9d 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x0000000034902faf 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:00.589976 [ 3863 ] {2923e721-34dd-40c3-9a22-dad5c49fe77a} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT logTrace([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.591687 [ 3863 ] {2923e721-34dd-40c3-9a22-dad5c49fe77a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 3, should be 1: In scope SELECT logTrace([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.615653 [ 3863 ] {cbda73cc-f58d-4a70-8776-47c330c17ec3} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lowCardinalityIndices([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.617104 [ 3863 ] {cbda73cc-f58d-4a70-8776-47c330c17ec3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityIndices([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.640862 [ 3863 ] {f92c1023-c220-410c-989c-909b3425b7f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lowCardinalityKeys([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.642399 [ 3863 ] {f92c1023-c220-410c-989c-909b3425b7f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 3, should be 1: In scope SELECT lowCardinalityKeys([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.666192 [ 3863 ] {ace80ffd-acab-48db-92b0-87f314ac0832} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lower([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.667655 [ 3863 ] {ace80ffd-acab-48db-92b0-87f314ac0832} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 3, should be 1: In scope SELECT lower([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.689248 [ 3863 ] {ebfdfadc-beff-464f-8bc5-7ac67ce9bef2} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lowerUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.690843 [ 3863 ] {ebfdfadc-beff-464f-8bc5-7ac67ce9bef2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 3, should be 1: In scope SELECT lowerUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.712927 [ 3863 ] {4016efb5-5290-48ee-aab7-941e116592bf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPad, should be string: In scope SELECT lpad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lpad([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.714503 [ 3863 ] {4016efb5-5290-48ee-aab7-941e116592bf} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function leftPad, should be string: In scope SELECT lpad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:00.748569 [ 3863 ] {8e214cb4-e8cd-4b4c-8720-dc51c0b296fe} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT lttb([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.750163 [ 3863 ] {8e214cb4-e8cd-4b4c-8720-dc51c0b296fe} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.771086 [ 3863 ] {8f2fbbe3-39de-4a81-a265-fa3a07d43f9e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT makeDate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT makeDate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.772259 [ 3863 ] {8f2fbbe3-39de-4a81-a265-fa3a07d43f9e} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT makeDate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:00.801495 [ 3863 ] {2e19fc0f-8cc3-4305-9c83-d21036c64206} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT makeDate32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT makeDate32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.803146 [ 3863 ] {2e19fc0f-8cc3-4305-9c83-d21036c64206} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Array(Nullable(Nothing)): In scope SELECT makeDate32([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:00.823105 [ 3863 ] {c830c60e-718e-4910-85b8-8e5dfa6b018d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 3 arguments: In scope SELECT makeDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT makeDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.824348 [ 3863 ] {c830c60e-718e-4910-85b8-8e5dfa6b018d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 3 arguments: In scope SELECT makeDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.845358 [ 3863 ] {8980d1f5-7b53-4620-a651-b42d8624d113} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 3 arguments: In scope SELECT makeDateTime64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT makeDateTime64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.846975 [ 3863 ] {8980d1f5-7b53-4620-a651-b42d8624d113} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 3 arguments: In scope SELECT makeDateTime64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.866221 [ 3863 ] {0539ee6a-8997-41dd-b6ce-5113631da0c2} executeQuery: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mannWhitneyUTest([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.867369 [ 3863 ] {0539ee6a-8997-41dd-b6ce-5113631da0c2} TCPHandler: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.892305 [ 3863 ] {066054dd-189a-4220-ab09-78a643628224} executeQuery: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT map([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.893632 [ 3863 ] {066054dd-189a-4220-ab09-78a643628224} TCPHandler: Code: 42. DB::Exception: Function map requires even number of arguments, but 3 given: In scope SELECT map([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:00.913078 [ 3863 ] {b45ec7ed-e9b7-437c-bc84-801d69e665ed} executeQuery: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapAdd([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.914492 [ 3863 ] {b45ec7ed-e9b7-437c-bc84-801d69e665ed} TCPHandler: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:00.934059 [ 3863 ] {ad6287d9-58d3-40a9-a343-fcabd309a3e8} executeQuery: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapAll([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.935450 [ 3863 ] {ad6287d9-58d3-40a9-a343-fcabd309a3e8} TCPHandler: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:00.956133 [ 3863 ] {7e89181c-e031-42b1-9e17-6bf9d8e84862} executeQuery: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapApply([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.957435 [ 3863 ] {7e89181c-e031-42b1-9e17-6bf9d8e84862} TCPHandler: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:00.977689 [ 3863 ] {fa93b93d-14d9-43a5-ab31-dec5d133af06} executeQuery: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapConcat([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.979116 [ 3863 ] {fa93b93d-14d9-43a5-ab31-dec5d133af06} TCPHandler: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:00.998770 [ 3863 ] {af96e931-e891-4f3b-afee-59a7d81e3bf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapContains([NULL], [NULL], [NULL]);) 2025.03.31 19:01:00.999947 [ 3863 ] {af96e931-e891-4f3b-afee-59a7d81e3bf8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 3, should be 2: In scope SELECT mapContains([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.019962 [ 3863 ] {657437f0-9d5f-42a6-9330-ed5e7fbe01ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContainsKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapContainsKeyLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapContainsKeyLike([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.021145 [ 3863 ] {657437f0-9d5f-42a6-9330-ed5e7fbe01ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContainsKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapContainsKeyLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.040055 [ 3863 ] {ef3f9af3-2858-4070-9e03-69114e95a272} executeQuery: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapExists([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.041264 [ 3863 ] {ef3f9af3-2858-4070-9e03-69114e95a272} TCPHandler: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.061926 [ 3863 ] {e06ec36a-5079-4964-8279-ec015a69afdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapExtractKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapExtractKeyLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapExtractKeyLike([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.063460 [ 3863 ] {e06ec36a-5079-4964-8279-ec015a69afdf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapExtractKeyLike doesn't match: passed 3, should be 2: In scope SELECT mapExtractKeyLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.091702 [ 3863 ] {b84a913d-41d9-42c4-8290-4acd16f4a5b4} executeQuery: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapFilter([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.093058 [ 3863 ] {b84a913d-41d9-42c4-8290-4acd16f4a5b4} TCPHandler: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.116739 [ 3863 ] {e859e164-48c2-42c6-9964-f7839c28258b} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapFromArrays([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.118265 [ 3863 ] {e859e164-48c2-42c6-9964-f7839c28258b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 3, should be 2: In scope SELECT mapFromArrays([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.139509 [ 3863 ] {3e7acd4f-b933-4378-8433-3ce8561c71d9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT mapFromString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapFromString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.140841 [ 3863 ] {3e7acd4f-b933-4378-8433-3ce8561c71d9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT mapFromString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.160212 [ 3863 ] {db6d5901-8a4d-44f5-94e4-44f0db41c01b} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapKeys([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.161639 [ 3863 ] {db6d5901-8a4d-44f5-94e4-44f0db41c01b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 3, should be 1: In scope SELECT mapKeys([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.179600 [ 3863 ] {ef6ccfef-d1b5-4ba7-b64e-83047d9cb6af} executeQuery: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapPartialReverseSort([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.180714 [ 3863 ] {ef6ccfef-d1b5-4ba7-b64e-83047d9cb6af} TCPHandler: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.198490 [ 3863 ] {d2e5aff0-a982-4b4e-b19c-1a87a72a47bf} executeQuery: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapPartialSort([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.199567 [ 3863 ] {d2e5aff0-a982-4b4e-b19c-1a87a72a47bf} TCPHandler: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.217625 [ 3863 ] {3e7395c7-f9bf-4e1b-b35f-a824beb46e15} executeQuery: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type Nullable(Nothing): In scope SELECT mapPopulateSeries([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapPopulateSeries([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.218839 [ 3863 ] {3e7395c7-f9bf-4e1b-b35f-a824beb46e15} TCPHandler: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type Nullable(Nothing): In scope SELECT mapPopulateSeries([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.270912 [ 3863 ] {ee84c403-24c6-42e8-8f49-f549a763a6c3} executeQuery: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapReverseSort([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.272278 [ 3863 ] {ee84c403-24c6-42e8-8f49-f549a763a6c3} TCPHandler: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.294318 [ 3863 ] {090ed3b0-cd4c-4e1b-a2ea-98003b5d3f41} executeQuery: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapSort([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.295664 [ 3863 ] {090ed3b0-cd4c-4e1b-a2ea-98003b5d3f41} TCPHandler: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.318022 [ 3863 ] {3fe94d92-c07e-4bc0-8bd5-11eff02f205b} executeQuery: Code: 43. DB::Exception: mapSubtract only accepts maps: In scope SELECT mapSubtract([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapSubtract([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.319215 [ 3863 ] {3fe94d92-c07e-4bc0-8bd5-11eff02f205b} TCPHandler: Code: 43. DB::Exception: mapSubtract only accepts maps: In scope SELECT mapSubtract([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.341441 [ 3863 ] {cac805b2-4261-4bb2-b89e-f0991970cbbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapUpdate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.342898 [ 3863 ] {cac805b2-4261-4bb2-b89e-f0991970cbbb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.423126 [ 3863 ] {f98f6589-7ab6-47f8-9d66-ca77f1897319} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mapValues([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.424414 [ 3863 ] {f98f6589-7ab6-47f8-9d66-ca77f1897319} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 3, should be 1: In scope SELECT mapValues([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.502575 [ 3863 ] {7b70ee69-176e-424b-9e54-e6cd931d4be0} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT match([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.503918 [ 3863 ] {7b70ee69-176e-424b-9e54-e6cd931d4be0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 3, should be 2: In scope SELECT match([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.525169 [ 3863 ] {fc41ebd6-e8ee-4489-883d-9f078dd56d39} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT materialize([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.526402 [ 3863 ] {fc41ebd6-e8ee-4489-883d-9f078dd56d39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 3, should be 1: In scope SELECT materialize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.548625 [ 3863 ] {2d43242a-a767-4728-93f3-29c0ca6173eb} executeQuery: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT max([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.550035 [ 3863 ] {2d43242a-a767-4728-93f3-29c0ca6173eb} TCPHandler: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.570807 [ 3863 ] {966530ba-c87f-4ef6-b55f-df81b61de773} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT max2([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.571986 [ 3863 ] {966530ba-c87f-4ef6-b55f-df81b61de773} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 3, should be 2: In scope SELECT max2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.594626 [ 3863 ] {53466b2b-e2d0-4e0d-9526-6fe460002389} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT maxIntersections([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.595912 [ 3863 ] {53466b2b-e2d0-4e0d-9526-6fe460002389} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.677859 [ 3863 ] {3375fa71-ae4a-4d42-a71e-f9c6a30c0c46} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT maxIntersectionsPosition([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.679263 [ 3863 ] {3375fa71-ae4a-4d42-a71e-f9c6a30c0c46} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.702272 [ 3863 ] {1f048366-9fe1-40cb-9a5e-ba1e72ecf591} executeQuery: Code: 43. DB::Exception: Cannot calculate -Map of type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT maxMappedArrays([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.703457 [ 3863 ] {1f048366-9fe1-40cb-9a5e-ba1e72ecf591} TCPHandler: Code: 43. DB::Exception: Cannot calculate -Map of type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.823536 [ 3863 ] {c4b727bf-ff35-4018-9d32-44dfd1d46996} executeQuery: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT meanZTest([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.825067 [ 3863 ] {c4b727bf-ff35-4018-9d32-44dfd1d46996} TCPHandler: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:01.846820 [ 3863 ] {6e0df392-4c8e-4e99-9dbb-53d92d884324} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT median([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.848247 [ 3863 ] {6e0df392-4c8e-4e99-9dbb-53d92d884324} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.869340 [ 3863 ] {08fb32b9-e052-46a5-8e0b-ec8dbd1c51cf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianBFloat16([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.870948 [ 3863 ] {08fb32b9-e052-46a5-8e0b-ec8dbd1c51cf} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.891676 [ 3863 ] {b2185b4f-66b4-4885-a6fe-4ff4d031f0bd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianBFloat16Weighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.893159 [ 3863 ] {b2185b4f-66b4-4885-a6fe-4ff4d031f0bd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.915970 [ 3863 ] {d1881c7e-0ba6-4562-a012-cb358448d903} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianDD([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.917484 [ 3863 ] {d1881c7e-0ba6-4562-a012-cb358448d903} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.941141 [ 3863 ] {a673d445-5c5d-468d-9c20-7c98c0b4b995} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianDeterministic([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.942579 [ 3863 ] {a673d445-5c5d-468d-9c20-7c98c0b4b995} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.964130 [ 3863 ] {6465b1df-51c3-409a-bb77-24106dd489f5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianExact([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.965439 [ 3863 ] {6465b1df-51c3-409a-bb77-24106dd489f5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:01.987983 [ 3863 ] {b9f91097-03a1-4907-8991-f2e3fe9064e7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianExactHigh([NULL], [NULL], [NULL]);) 2025.03.31 19:01:01.989272 [ 3863 ] {b9f91097-03a1-4907-8991-f2e3fe9064e7} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.091117 [ 3863 ] {7386da00-8303-4845-ac82-c7a4143f4ffd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianExactLow([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.092608 [ 3863 ] {7386da00-8303-4845-ac82-c7a4143f4ffd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.113890 [ 3863 ] {47261008-67f4-4b19-ada5-be8295102045} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianExactWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.115138 [ 3863 ] {47261008-67f4-4b19-ada5-be8295102045} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.136781 [ 3863 ] {56791ddf-71ad-400a-bf95-8d274c3e30fa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianGK([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.138259 [ 3863 ] {56791ddf-71ad-400a-bf95-8d274c3e30fa} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.156318 [ 3863 ] {3cd11005-bab6-4219-a539-1e7390b47a5b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianInterpolatedWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.157470 [ 3863 ] {3cd11005-bab6-4219-a539-1e7390b47a5b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.178548 [ 3863 ] {bed4252b-0c4b-43fe-a34b-5a26c63f3274} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianTDigest([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.180466 [ 3863 ] {bed4252b-0c4b-43fe-a34b-5a26c63f3274} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.200311 [ 3863 ] {1b136363-e761-4563-aa5d-eb1d968cbd15} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianTDigestWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.201885 [ 3863 ] {1b136363-e761-4563-aa5d-eb1d968cbd15} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.220820 [ 3863 ] {deee2bfe-5116-4148-b3ff-c83c2e23d47f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianTiming([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.222237 [ 3863 ] {deee2bfe-5116-4148-b3ff-c83c2e23d47f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.277428 [ 3831 ] {80647316-163d-44be-b7a6-d5f116946c3f} executeQuery: Code: 57. DB::Exception: Table test.hits_log already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37482) (comment: 00077_log_tinylog_stripelog.sql) (in query: CREATE TABLE test.hits_log (CounterID UInt32, AdvEngineID UInt8, RegionID UInt32, SearchPhrase String, UserID UInt64) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:02.279005 [ 3831 ] {80647316-163d-44be-b7a6-d5f116946c3f} TCPHandler: Code: 57. DB::Exception: Table test.hits_log 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:02.279849 [ 3863 ] {ec6b8537-eddf-48cc-ad41-29363812ed79} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT medianTimingWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.280778 [ 3863 ] {ec6b8537-eddf-48cc-ad41-29363812ed79} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.299016 [ 3863 ] {c5382233-aa04-4cef-8d1c-19f146d7173e} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT metroHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT metroHash64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.300239 [ 3863 ] {c5382233-aa04-4cef-8d1c-19f146d7173e} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT metroHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:02.411792 [ 3863 ] {b71b1418-f4d7-4cc8-9110-52b087e8c465} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT mid([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mid([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.413368 [ 3863 ] {b71b1418-f4d7-4cc8-9110-52b087e8c465} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT mid([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.435598 [ 3863 ] {a9f21415-5891-4b1b-951b-047fe7ad7e6d} executeQuery: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT min([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.437010 [ 3863 ] {a9f21415-5891-4b1b-951b-047fe7ad7e6d} TCPHandler: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.458442 [ 3863 ] {7a6bcceb-915d-46d5-868f-8dc3ac5203a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT min2([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.460915 [ 3863 ] {7a6bcceb-915d-46d5-868f-8dc3ac5203a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 3, should be 2: In scope SELECT min2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.481454 [ 3863 ] {6348be18-e93c-4ac9-bebc-2f7cfc0b0cdc} executeQuery: Code: 43. DB::Exception: Cannot calculate -Map of type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT minMappedArrays([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.482698 [ 3863 ] {6348be18-e93c-4ac9-bebc-2f7cfc0b0cdc} TCPHandler: Code: 43. DB::Exception: Cannot calculate -Map of type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.502258 [ 3863 ] {eb653dc7-c1da-4228-9c94-4af301966ad8} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT minSampleSizeContinous([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.503381 [ 3863 ] {eb653dc7-c1da-4228-9c94-4af301966ad8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinous([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.522153 [ 3863 ] {180c66f9-aa34-4048-b2bb-184bb3c7ba95} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT minSampleSizeContinuous([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.523449 [ 3863 ] {180c66f9-aa34-4048-b2bb-184bb3c7ba95} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 3, should be 5: In scope SELECT minSampleSizeContinuous([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.601248 [ 3863 ] {b5f48c9f-86e4-440a-9542-821180d45d45} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT minSampleSizeConversion([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.602600 [ 3863 ] {b5f48c9f-86e4-440a-9542-821180d45d45} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 3, should be 4: In scope SELECT minSampleSizeConversion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.624593 [ 3863 ] {be63b03a-06c1-404b-b39f-933363844f49} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT minus([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.666496 [ 3863 ] {be63b03a-06c1-404b-b39f-933363844f49} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 3, should be 2: In scope SELECT minus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.687748 [ 3863 ] {57581100-969a-48d2-b991-8f4eeb6ff978} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mismatches([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.689217 [ 3863 ] {57581100-969a-48d2-b991-8f4eeb6ff978} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 3, should be 2: In scope SELECT mismatches([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.707054 [ 3863 ] {9845d8ab-cedf-47c5-831d-236984e9c84e} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mod([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.708246 [ 3863 ] {9845d8ab-cedf-47c5-831d-236984e9c84e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT mod([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.726921 [ 3863 ] {d1c4feee-0dbe-4f2b-b6ed-193dde64ac32} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT modulo([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.728073 [ 3863 ] {d1c4feee-0dbe-4f2b-b6ed-193dde64ac32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 3, should be 2: In scope SELECT modulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.792909 [ 3863 ] {ee937b9d-c125-46e6-8194-95300f2e02af} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT moduloLegacy([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.794529 [ 3863 ] {ee937b9d-c125-46e6-8194-95300f2e02af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 3, should be 2: In scope SELECT moduloLegacy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.816435 [ 3863 ] {d2075496-aa8a-4d9f-aec7-9675d526a2db} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT moduloOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.817946 [ 3863 ] {d2075496-aa8a-4d9f-aec7-9675d526a2db} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 3, should be 2: In scope SELECT moduloOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.838070 [ 3863 ] {2c5e4309-2e88-456d-980e-588907fc77db} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT monthName([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.839434 [ 3863 ] {2c5e4309-2e88-456d-980e-588907fc77db} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 3, should be 1: In scope SELECT monthName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.858497 [ 3863 ] {db33c6dc-1b91-4dcb-90b8-50ece2be85c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mortonDecode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.859966 [ 3863 ] {db33c6dc-1b91-4dcb-90b8-50ece2be85c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 3, should be 2: In scope SELECT mortonDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:02.878485 [ 3863 ] {e634398c-da2b-462c-9f80-9834e13aba84} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT mortonEncode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.879883 [ 3863 ] {e634398c-da2b-462c-9f80-9834e13aba84} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:02.889615 [ 4240 ] {40e1947d-82f4-4202-bda4-e7bdd3ee4422} 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.10457.altinitytest (altinity build)) (from [::1]:37474) (comment: 01160_table_dependencies.sh) (in query: detach database test_krdjlok0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:01:02.891218 [ 4240 ] {40e1947d-82f4-4202-bda4-e7bdd3ee4422} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:01:02.897384 [ 3863 ] {6f97bbfd-fbe5-4213-a045-6385a80c78f7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAllIndices: In scope SELECT multiFuzzyMatchAllIndices([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiFuzzyMatchAllIndices([NULL], [NULL], [NULL]);) 2025.03.31 19:01:02.898657 [ 3863 ] {6f97bbfd-fbe5-4213-a045-6385a80c78f7} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAllIndices: In scope SELECT multiFuzzyMatchAllIndices([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:03.029648 [ 3863 ] {f3922ccf-2cb4-4ddc-960a-9c1999823808} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiFuzzyMatchAny([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.031557 [ 3863 ] {f3922ccf-2cb4-4ddc-960a-9c1999823808} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAny: In scope SELECT multiFuzzyMatchAny([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:03.149408 [ 3863 ] {9a8a9e32-f47a-4e66-83e8-df06c5396f10} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAnyIndex: In scope SELECT multiFuzzyMatchAnyIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiFuzzyMatchAnyIndex([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.150718 [ 3863 ] {9a8a9e32-f47a-4e66-83e8-df06c5396f10} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function multiFuzzyMatchAnyIndex: In scope SELECT multiFuzzyMatchAnyIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:03.172300 [ 3863 ] {00b9ace6-98cd-4c80-99af-3aa7e4ad02d8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT multiIf([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiIf([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.173450 [ 3863 ] {00b9ace6-98cd-4c80-99af-3aa7e4ad02d8} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument (condition) of function multiIf. Must be UInt8.: In scope SELECT multiIf([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:03.197039 [ 3863 ] {1063312c-fbd9-4a1a-9d75-bd0b7dfd0729} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiMatchAllIndices([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.198453 [ 3863 ] {1063312c-fbd9-4a1a-9d75-bd0b7dfd0729} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 3, should be 2: In scope SELECT multiMatchAllIndices([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.218297 [ 3863 ] {c23989ff-94bb-42be-9654-fa25a0fae7a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiMatchAny([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.219450 [ 3863 ] {c23989ff-94bb-42be-9654-fa25a0fae7a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 3, should be 2: In scope SELECT multiMatchAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.238156 [ 3863 ] {cdd1a53b-039a-4573-829e-d080046b56dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiMatchAnyIndex([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.239411 [ 3863 ] {cdd1a53b-039a-4573-829e-d080046b56dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 3, should be 2: In scope SELECT multiMatchAnyIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.258062 [ 3863 ] {624a9fd0-c8a9-442a-8938-f0f6fcce54db} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchAllPositions([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.259144 [ 3863 ] {624a9fd0-c8a9-442a-8938-f0f6fcce54db} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositions([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.277860 [ 3863 ] {a14672f5-d74b-4033-9e3b-97aeecbd8ce3} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.278953 [ 3863 ] {a14672f5-d74b-4033-9e3b-97aeecbd8ce3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.298721 [ 3863 ] {b3391c8a-23e5-46c4-9a3c-5a083eba9e65} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.301831 [ 3863 ] {b3391c8a-23e5-46c4-9a3c-5a083eba9e65} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.322758 [ 3863 ] {7bf93199-ffd4-4915-be4f-76f932960cf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchAllPositionsUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.323988 [ 3863 ] {7bf93199-ffd4-4915-be4f-76f932960cf8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAllPositionsUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.346084 [ 3863 ] {73339809-a87f-4b74-be68-16c56fb2ac29} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchAny([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.347642 [ 3863 ] {73339809-a87f-4b74-be68-16c56fb2ac29} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 3, should be 2: In scope SELECT multiSearchAny([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.366171 [ 3863 ] {a23981e7-0522-4410-b6b4-dd603712446c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchAnyCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.367354 [ 3863 ] {a23981e7-0522-4410-b6b4-dd603712446c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.385664 [ 3863 ] {610a9a55-3712-4af7-b5d3-8df2728f2bfb} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.387234 [ 3863 ] {610a9a55-3712-4af7-b5d3-8df2728f2bfb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.408570 [ 3863 ] {1387552c-c260-48b0-b9cb-29281a8149f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchAnyUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.410155 [ 3863 ] {1387552c-c260-48b0-b9cb-29281a8149f2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchAnyUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.473985 [ 3863 ] {2012abd3-d595-4257-b9bb-5aa87345e0ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchFirstIndex([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.475542 [ 3863 ] {2012abd3-d595-4257-b9bb-5aa87345e0ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.496265 [ 3863 ] {d82ab501-c8e7-4114-ab9d-9cd48bc3a6e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.497630 [ 3863 ] {d82ab501-c8e7-4114-ab9d-9cd48bc3a6e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.518069 [ 3863 ] {0ee28297-043b-4c21-8b65-43bb4208a233} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.519572 [ 3863 ] {0ee28297-043b-4c21-8b65-43bb4208a233} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.578306 [ 3863 ] {097bd678-0e9b-40ae-aca7-92bbd8ff1a38} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchFirstIndexUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.579537 [ 3863 ] {097bd678-0e9b-40ae-aca7-92bbd8ff1a38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstIndexUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.599956 [ 3863 ] {447b85f2-c3a3-49f1-a1a6-6c5d2311ed76} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchFirstPosition([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.601023 [ 3863 ] {447b85f2-c3a3-49f1-a1a6-6c5d2311ed76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPosition([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.617939 [ 3863 ] {45c575f6-e962-44b0-9e2e-38d61f8806c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.618983 [ 3863 ] {45c575f6-e962-44b0-9e2e-38d61f8806c8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.654328 [ 3830 ] {34915f4f-790a-4eca-bf4e-2575af0782ee} executeQuery: Code: 57. DB::Exception: Table test_5.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00163_column_oriented_formats.sh) (in query: /* ddl_entry=query-0000000012 */ CREATE TABLE test_5.`00163_column_oriented` UUID '2b014cb5-7925-4e31-a59f-bc9fcf2e8fd4' (`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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:01:03.658644 [ 3830 ] {34915f4f-790a-4eca-bf4e-2575af0782ee} executeQuery: Code: 57. DB::Exception: Table test_5.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37528) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:01:03.660081 [ 3830 ] {34915f4f-790a-4eca-bf4e-2575af0782ee} TCPHandler: Code: 57. DB::Exception: Table test_5.`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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:01:03.719177 [ 3863 ] {a4357210-7504-4903-a77f-7721bc304c0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.720453 [ 3863 ] {a4357210-7504-4903-a77f-7721bc304c0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.815610 [ 3863 ] {3eb82c77-34b0-4b72-9f79-c53d8339ea78} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiSearchFirstPositionUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.817010 [ 3863 ] {3eb82c77-34b0-4b72-9f79-c53d8339ea78} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 3, should be 2: In scope SELECT multiSearchFirstPositionUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.843468 [ 3863 ] {d44f4d6c-6ea0-420e-aba5-161e6963e566} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiply([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.845087 [ 3863 ] {d44f4d6c-6ea0-420e-aba5-161e6963e566} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 3, should be 2: In scope SELECT multiply([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:03.867406 [ 3863 ] {f46eba71-bcab-4abf-be95-db111c5b9561} executeQuery: Code: 43. DB::Exception: Arguments for multiplyDecimal function must be Decimal: In scope SELECT multiplyDecimal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT multiplyDecimal([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.868579 [ 3863 ] {f46eba71-bcab-4abf-be95-db111c5b9561} TCPHandler: Code: 43. DB::Exception: Arguments for multiplyDecimal function must be Decimal: In scope SELECT multiplyDecimal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:03.935910 [ 3863 ] {efe87217-158f-4efb-a273-4258ffd8165e} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT murmurHash2_32([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT murmurHash2_32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.937280 [ 3863 ] {efe87217-158f-4efb-a273-4258ffd8165e} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT murmurHash2_32([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:03.957436 [ 3863 ] {c0788793-682e-486a-bf1e-9311901e6475} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT murmurHash2_64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT murmurHash2_64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.958905 [ 3863 ] {c0788793-682e-486a-bf1e-9311901e6475} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT murmurHash2_64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:03.974645 [ 4734 ] {7455aa97-2cbe-4bd5-8f4f-6a893e44523d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=721). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37504) (comment: 00157_cache_dictionary.sql) (in query: SELECT count() FROM (SELECT WatchID, arrayDistinct(groupArray(dictGetUInt64( 'db_dict.cache_hits', 'UserID', toUInt64(WatchID)))) as arr FROM test.hits_1m PREWHERE WatchID % 13 == 0 GROUP BY WatchID order by length(arr) desc) WHERE arr = [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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:03.977379 [ 4734 ] {7455aa97-2cbe-4bd5-8f4f-6a893e44523d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:03.982874 [ 3863 ] {c89b9393-0ee0-48ea-bfdc-872961f07f9f} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT murmurHash3_128([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT murmurHash3_128([NULL], [NULL], [NULL]);) 2025.03.31 19:01:03.984325 [ 3863 ] {c89b9393-0ee0-48ea-bfdc-872961f07f9f} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT murmurHash3_128([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:04.076152 [ 3863 ] {7dad5b74-d0d1-44da-8f51-9f7c505c91f9} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT murmurHash3_32([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT murmurHash3_32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.077559 [ 3863 ] {7dad5b74-d0d1-44da-8f51-9f7c505c91f9} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT murmurHash3_32([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:04.096107 [ 3863 ] {2b5a4d6f-1b8f-47ad-9b3d-53d5817cc4d8} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT murmurHash3_64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT murmurHash3_64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.097218 [ 3863 ] {2b5a4d6f-1b8f-47ad-9b3d-53d5817cc4d8} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT murmurHash3_64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:04.114576 [ 3863 ] {fc82f882-67fb-4357-8182-36a3556f5fd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT negate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.115724 [ 3863 ] {fc82f882-67fb-4357-8182-36a3556f5fd7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 3, should be 1: In scope SELECT negate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.132764 [ 3863 ] {3f94fba1-dc2d-49a3-81f5-f6d3ab4fc2e6} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT neighbor([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.195921 [ 3863 ] {3f94fba1-dc2d-49a3-81f5-f6d3ab4fc2e6} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.03.31 19:01:04.216754 [ 3863 ] {abb4b6ea-19d2-4441-bf5f-afdae3f43473} executeQuery: Code: 36. DB::Exception: First argument for function nested must be constant column with array of strings: In scope SELECT nested([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT nested([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.218155 [ 3863 ] {abb4b6ea-19d2-4441-bf5f-afdae3f43473} TCPHandler: Code: 36. DB::Exception: First argument for function nested must be constant column with array of strings: In scope SELECT nested([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.03.31 19:01:04.239506 [ 3863 ] {f144f731-5154-48c0-afd1-97cf91406b96} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT netloc([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.240843 [ 3863 ] {f144f731-5154-48c0-afd1-97cf91406b96} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 3, should be 1: In scope SELECT netloc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.261941 [ 3863 ] {2884853d-fe8f-4827-85df-c0aea8fb895e} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.263225 [ 3863 ] {2884853d-fe8f-4827-85df-c0aea8fb895e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 3, should be 2: In scope SELECT ngramDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.306678 [ 3863 ] {ce820a05-904b-45a6-a68a-4657a3456ed2} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramDistanceCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.308319 [ 3863 ] {ce820a05-904b-45a6-a68a-4657a3456ed2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.328529 [ 3922 ] {b987a22f-725e-40ad-9e7d-69132831ea06} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 128.02 MiB (attempt to allocate chunk of 134239432 bytes), maximum: 95.37 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37438) (comment: 01910_memory_tracking_topk.sql) (in query: SELECT length(topK(5592405)(tuple(number))) FROM numbers(10) GROUP BY number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./src/Common/AllocatorWithMemoryTracking.h:33: AllocatorWithMemoryTracking::Counter, std::default_delete::Counter>>>::allocate(unsigned long) @ 0x000000002ef5c291 8. ./contrib/llvm-project/libcxx/include/vector:925: DB::SpaceSaving::resize(unsigned long) @ 0x000000002ef5a498 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:0: DB::(anonymous namespace)::AggregateFunctionTopKGeneric::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x000000002edf5924 10. ./src/AggregateFunctions/IAggregateFunction.h:466: DB::IAggregateFunctionHelper>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x000000002edf76e9 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000033b520ee 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1079: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000034020937 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003401c3db 14. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000033d57fcf 15. ./build_docker/./src/Interpreters/Aggregator.cpp:811: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000033b4d65b 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1478: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5a4e7 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b75ea94 18. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b752814 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 27. ? @ 0x00007f038ce47ac3 28. ? @ 0x00007f038ced9850 2025.03.31 19:01:04.330340 [ 3922 ] {b987a22f-725e-40ad-9e7d-69132831ea06} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 128.02 MiB (attempt to allocate chunk of 134239432 bytes), maximum: 95.37 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./src/Common/AllocatorWithMemoryTracking.h:33: AllocatorWithMemoryTracking::Counter, std::default_delete::Counter>>>::allocate(unsigned long) @ 0x000000002ef5c291 8. ./contrib/llvm-project/libcxx/include/vector:925: DB::SpaceSaving::resize(unsigned long) @ 0x000000002ef5a498 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionTopK.cpp:0: DB::(anonymous namespace)::AggregateFunctionTopKGeneric::add(char*, DB::IColumn const**, unsigned long, DB::Arena*) const @ 0x000000002edf5924 10. ./src/AggregateFunctions/IAggregateFunction.h:466: DB::IAggregateFunctionHelper>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x000000002edf76e9 11. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000033b520ee 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1079: void DB::Aggregator::executeImplBatch, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000034020937 13. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::ColumnsHashing::HashMethodOneNumber, char*, unsigned long, true, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000003401c3db 14. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>>(DB::AggregationMethodOneNumber, HashTableNoState, PairNoInit>, HashCRC32, HashTableGrowerWithPrecalculation<8ul>, Allocator>, true, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000033d57fcf 15. ./build_docker/./src/Interpreters/Aggregator.cpp:811: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000033b4d65b 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1478: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5a4e7 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b75ea94 18. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b752814 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 27. ? @ 0x00007f038ce47ac3 28. ? @ 0x00007f038ced9850 2025.03.31 19:01:04.332653 [ 3863 ] {5a82598e-699e-44df-8af5-22b3a125a12e} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramDistanceCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.334536 [ 3863 ] {5a82598e-699e-44df-8af5-22b3a125a12e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.357174 [ 3863 ] {1ac97f7d-e664-4994-80f6-3eba4ee150ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramDistanceUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.359185 [ 3863 ] {1ac97f7d-e664-4994-80f6-3eba4ee150ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramDistanceUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.387064 [ 3831 ] {99218271-d0f7-4dff-b716-dfbff2eae308} executeQuery: Code: 82. DB::Exception: Database test_krdjlok0 already exists. (DATABASE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37520) (comment: 01160_table_dependencies.sh) (in query: attach database test_krdjlok0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034885a47 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 2025.03.31 19:01:04.388316 [ 3831 ] {99218271-d0f7-4dff-b716-dfbff2eae308} TCPHandler: Code: 82. DB::Exception: Database test_krdjlok0 already exists. (DATABASE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:146: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034885a47 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 2025.03.31 19:01:04.390378 [ 3863 ] {cd8e369c-4fd3-4729-a573-8d9753fea1be} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramMinHash([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.391744 [ 3863 ] {cd8e369c-4fd3-4729-a573-8d9753fea1be} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.411828 [ 3863 ] {3efe5d91-b26b-4aec-9e0f-78e9c4637e08} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramMinHashArg([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.413150 [ 3863 ] {3efe5d91-b26b-4aec-9e0f-78e9c4637e08} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.437122 [ 3863 ] {5e64a97b-a889-459d-89ff-96c43cca5a5b} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramMinHashArgCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.438611 [ 3863 ] {5e64a97b-a889-459d-89ff-96c43cca5a5b} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.457731 [ 3863 ] {59fda6b1-6653-47c0-af19-453401eb808e} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.458931 [ 3863 ] {59fda6b1-6653-47c0-af19-453401eb808e} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.477153 [ 3863 ] {82bfcca6-c77e-492f-bbf9-43921a8ff8f3} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramMinHashArgUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.478456 [ 3863 ] {82bfcca6-c77e-492f-bbf9-43921a8ff8f3} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashArgUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.497954 [ 3863 ] {9faf4db9-719e-4373-9587-bbca9ba2c958} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramMinHashCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.499209 [ 3863 ] {9faf4db9-719e-4373-9587-bbca9ba2c958} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.519580 [ 3863 ] {751fda3b-3975-4efd-b2d9-2faa509f1fff} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.521012 [ 3863 ] {751fda3b-3975-4efd-b2d9-2faa509f1fff} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.539277 [ 3863 ] {d720b468-f34c-45f6-95a6-754a74811ccd} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramMinHashUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.540646 [ 3863 ] {d720b468-f34c-45f6-95a6-754a74811ccd} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramMinHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.560000 [ 3863 ] {b6468315-d05b-471e-bf2d-d2ff448832a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramSearch([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.561379 [ 3863 ] {b6468315-d05b-471e-bf2d-d2ff448832a6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 3, should be 2: In scope SELECT ngramSearch([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.582274 [ 3863 ] {4cab1361-397b-4d06-bab2-3ed57027eaab} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramSearchCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.583856 [ 3863 ] {4cab1361-397b-4d06-bab2-3ed57027eaab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitive([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.604892 [ 3863 ] {58ea68ed-3ec6-43d7-aec9-188155a6f93e} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramSearchCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.606282 [ 3863 ] {58ea68ed-3ec6-43d7-aec9-188155a6f93e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.625592 [ 3863 ] {621c904f-a4eb-451b-ac53-c434de1758dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramSearchUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.626944 [ 3863 ] {621c904f-a4eb-451b-ac53-c434de1758dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 3, should be 2: In scope SELECT ngramSearchUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.649554 [ 3863 ] {55f40a18-5e96-4441-9c7c-f431c6f80a22} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramSimHash([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.651057 [ 3863 ] {55f40a18-5e96-4441-9c7c-f431c6f80a22} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.672491 [ 3863 ] {59233984-e798-42ee-96bf-85943bc008f3} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramSimHashCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.679607 [ 3863 ] {59233984-e798-42ee-96bf-85943bc008f3} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.703680 [ 3863 ] {a0231769-d099-4a31-8f54-82dca1191b23} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.705113 [ 3863 ] {a0231769-d099-4a31-8f54-82dca1191b23} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.724956 [ 3863 ] {63461209-360b-4794-b764-741181af9b51} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngramSimHashUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.726245 [ 3863 ] {63461209-360b-4794-b764-741181af9b51} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT ngramSimHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:04.745678 [ 3863 ] {b13eb2c2-bc1a-4d0b-a5f1-df09c417e620} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ngrams([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.797200 [ 3863 ] {b13eb2c2-bc1a-4d0b-a5f1-df09c417e620} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 3, should be 2: In scope SELECT ngrams([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.817445 [ 3863 ] {d12ba523-ea08-4c4b-bb3a-3c01288c92e8} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT nonNegativeDerivative([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.818905 [ 3863 ] {d12ba523-ea08-4c4b-bb3a-3c01288c92e8} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Array(Nullable(Nothing))' given. (BAD_ARGUMENTS) 2025.03.31 19:01:04.838026 [ 3863 ] {e09fd71f-b0f7-4ab5-8e7b-c40491a89491} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normL1([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.839301 [ 3863 ] {e09fd71f-b0f7-4ab5-8e7b-c40491a89491} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 3, should be 1: In scope SELECT normL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.857133 [ 3863 ] {c3389576-21b2-46f3-867b-91b33bede6e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normL2([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.954223 [ 3863 ] {c3389576-21b2-46f3-867b-91b33bede6e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 3, should be 1: In scope SELECT normL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:04.974870 [ 3863 ] {cc151ab3-6113-4e85-998c-ad447edf745c} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normL2Squared([NULL], [NULL], [NULL]);) 2025.03.31 19:01:04.976189 [ 3863 ] {cc151ab3-6113-4e85-998c-ad447edf745c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 3, should be 1: In scope SELECT normL2Squared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.063481 [ 3863 ] {09759199-34d7-4eab-a1ee-03c0ffccd6f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normLinf([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.064731 [ 3863 ] {09759199-34d7-4eab-a1ee-03c0ffccd6f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 3, should be 1: In scope SELECT normLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.086295 [ 3863 ] {d836687d-48ca-4728-9b57-5edfbb715fee} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normLp([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.087639 [ 3863 ] {d836687d-48ca-4728-9b57-5edfbb715fee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 3, should be 2: In scope SELECT normLp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.107384 [ 3863 ] {98a52807-03f7-498c-b9d1-d932c5d04b64} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizeL1([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.109153 [ 3863 ] {98a52807-03f7-498c-b9d1-d932c5d04b64} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL1([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.127468 [ 3863 ] {63e4a534-d8c1-42f6-b421-cb1dbb7e0112} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizeL2([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.128908 [ 3863 ] {63e4a534-d8c1-42f6-b421-cb1dbb7e0112} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 3, should be 1: In scope SELECT normalizeL2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.147564 [ 3863 ] {50a11489-4927-4093-861b-b90a1b956541} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizeLinf([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.148738 [ 3863 ] {50a11489-4927-4093-861b-b90a1b956541} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 3, should be 1: In scope SELECT normalizeLinf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.253451 [ 3863 ] {e778d2e0-f934-46f2-a668-eff5c727be54} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizeLp([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.254898 [ 3863 ] {e778d2e0-f934-46f2-a668-eff5c727be54} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 3, should be 2: In scope SELECT normalizeLp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.276262 [ 3863 ] {10cf6665-ea5e-423b-b599-992426996ae9} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizeQuery([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.277686 [ 3863 ] {10cf6665-ea5e-423b-b599-992426996ae9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 3, should be 1: In scope SELECT normalizeQuery([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.298133 [ 3863 ] {2efb8b09-83be-4407-aa42-d5fdc96594f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizeQueryKeepNames([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.299383 [ 3863 ] {2efb8b09-83be-4407-aa42-d5fdc96594f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizeQueryKeepNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.319420 [ 3863 ] {d934c1c9-4673-49b4-ab42-349cc2f6f743} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizeUTF8NFC([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.320778 [ 3863 ] {d934c1c9-4673-49b4-ab42-349cc2f6f743} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.382003 [ 4734 ] {e6f59149-6a9e-4445-8fa3-e82379351089} 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.10457.altinitytest (altinity build)) (from [::1]:37536) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832b4f7 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&) @ 0x000000003ba5a50f 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*) @ 0x0000000034b91a81 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&) @ 0x0000000034b94a8f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:05.383698 [ 4734 ] {e6f59149-6a9e-4445-8fa3-e82379351089} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832b4f7 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&) @ 0x000000003ba5a50f 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*) @ 0x0000000034b91a81 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&) @ 0x0000000034b94a8f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:05.435293 [ 3863 ] {8e23b04d-5627-43e7-93e0-8deb659bdc34} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizeUTF8NFD([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.436726 [ 3863 ] {8e23b04d-5627-43e7-93e0-8deb659bdc34} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.491776 [ 3863 ] {d7895a55-49b5-45a5-9c88-2bb6cb477326} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizeUTF8NFKC([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.493273 [ 3863 ] {d7895a55-49b5-45a5-9c88-2bb6cb477326} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.514074 [ 3863 ] {3b992391-64fc-42f4-a3c6-1e5225fbe69d} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizeUTF8NFKD([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.515668 [ 3863 ] {3b992391-64fc-42f4-a3c6-1e5225fbe69d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 3, should be 1: In scope SELECT normalizeUTF8NFKD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.599853 [ 3863 ] {3ff57af1-cb22-45e6-96e4-d04397979393} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizedQueryHash([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.601177 [ 3863 ] {3ff57af1-cb22-45e6-96e4-d04397979393} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.620319 [ 3863 ] {4baf656d-b045-4973-ac97-66da82da54dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT normalizedQueryHashKeepNames([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.621836 [ 3863 ] {4baf656d-b045-4973-ac97-66da82da54dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 3, should be 1: In scope SELECT normalizedQueryHashKeepNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.642883 [ 3863 ] {3af7017a-e70a-4f02-8512-301b551a010a} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT not([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.644209 [ 3863 ] {3af7017a-e70a-4f02-8512-301b551a010a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 3, should be 1: In scope SELECT not([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.665137 [ 3863 ] {d51609fa-b3d5-4bdc-9faa-7e2583fb46b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT notEmpty([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.666379 [ 3863 ] {d51609fa-b3d5-4bdc-9faa-7e2583fb46b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 3, should be 1: In scope SELECT notEmpty([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.686131 [ 3863 ] {1be055d3-c646-47b6-8a65-266e0d3dc83b} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT notEquals([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.687292 [ 3863 ] {1be055d3-c646-47b6-8a65-266e0d3dc83b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 3, should be 2: In scope SELECT notEquals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.706569 [ 3863 ] {5151597d-92b5-4340-ba21-ee03060bd9fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT notILike([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.707940 [ 3863 ] {5151597d-92b5-4340-ba21-ee03060bd9fe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 3, should be 2: In scope SELECT notILike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.727102 [ 3863 ] {1f1874de-527f-4210-895f-5c9751757bd3} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT notIn([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.728479 [ 3863 ] {1f1874de-527f-4210-895f-5c9751757bd3} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.812920 [ 3863 ] {a63f77b1-52bb-473b-ad4e-7ba6c970b09e} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT notInIgnoreSet([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.814484 [ 3863 ] {a63f77b1-52bb-473b-ad4e-7ba6c970b09e} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.835932 [ 3863 ] {0e11baae-d632-41b8-8459-62cd33fc9503} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT notLike([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.837119 [ 3863 ] {0e11baae-d632-41b8-8459-62cd33fc9503} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 3, should be 2: In scope SELECT notLike([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.854885 [ 3863 ] {3f312dd6-a761-4ca8-aa35-6119c656165c} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT notNullIn([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.856014 [ 3863 ] {3f312dd6-a761-4ca8-aa35-6119c656165c} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:05.873540 [ 3863 ] {5bf54254-2c15-4814-8ca0-18a3a087c356} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT notNullInIgnoreSet([NULL], [NULL], [NULL]);) 2025.03.31 19:01:05.874815 [ 3863 ] {5bf54254-2c15-4814-8ca0-18a3a087c356} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.100704 [ 3863 ] {d429565c-930c-40b2-bd5a-aaec0136ad40} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT now([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.102270 [ 3863 ] {d429565c-930c-40b2-bd5a-aaec0136ad40} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.120320 [ 3863 ] {490afb92-255f-48e3-8507-54400aacc630} executeQuery: Code: 34. DB::Exception: Arguments size of function now64 should be 0, or 1, or 2: In scope SELECT now64([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT now64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.121623 [ 3863 ] {490afb92-255f-48e3-8507-54400aacc630} TCPHandler: Code: 34. DB::Exception: Arguments size of function now64 should be 0, or 1, or 2: In scope SELECT now64([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:01:06.139524 [ 3863 ] {2b268666-eef3-470a-a794-2e807b57b098} executeQuery: Code: 34. DB::Exception: Arguments size of function nowInBlock should be 0 or 1: In scope SELECT nowInBlock([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT nowInBlock([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.140802 [ 3863 ] {2b268666-eef3-470a-a794-2e807b57b098} TCPHandler: Code: 34. DB::Exception: Arguments size of function nowInBlock should be 0 or 1: In scope SELECT nowInBlock([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:01:06.167797 [ 3863 ] {1016efdc-772d-4b17-88b6-d02f6bbaba3a} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT nth_value([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.169067 [ 3863 ] {1016efdc-772d-4b17-88b6-d02f6bbaba3a} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.189871 [ 3863 ] {b809af5d-dd82-4230-8d83-1aa811d31621} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ntile([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.191289 [ 3863 ] {b809af5d-dd82-4230-8d83-1aa811d31621} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.296122 [ 3863 ] {2e5acd5f-cb1c-4a29-a7ec-0a8d231565eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT nullIf([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.297446 [ 3863 ] {2e5acd5f-cb1c-4a29-a7ec-0a8d231565eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 3, should be 2: In scope SELECT nullIf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.316009 [ 3863 ] {549fe8ea-7cf8-41f6-a231-ab4361cac823} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT nullIn([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.317155 [ 3863 ] {549fe8ea-7cf8-41f6-a231-ab4361cac823} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.430554 [ 3863 ] {4b21d3f2-3f69-4cce-9289-b19c327d62bb} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT nullInIgnoreSet([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.431977 [ 3863 ] {4b21d3f2-3f69-4cce-9289-b19c327d62bb} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.452895 [ 3863 ] {1dbfff5a-8815-40fd-8830-5953fea1422d} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function or: In scope SELECT [NULL] OR [NULL] OR [NULL]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT or([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.454232 [ 3863 ] {1dbfff5a-8815-40fd-8830-5953fea1422d} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function or: In scope SELECT [NULL] OR [NULL] OR [NULL]. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:06.473454 [ 3863 ] {795fefb9-d971-49df-b41c-15558fbe2fad} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.474833 [ 3863 ] {795fefb9-d971-49df-b41c-15558fbe2fad} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:06.494254 [ 3863 ] {5431446f-b0d2-4d47-b4dd-cc5d9bfb1a6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTime32BestEffort([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.495696 [ 3863 ] {5431446f-b0d2-4d47-b4dd-cc5d9bfb1a6d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.583530 [ 3863 ] {92461b7d-bc88-4e67-ad24-1c0798c31cf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTime32BestEffortOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.584931 [ 3863 ] {92461b7d-bc88-4e67-ad24-1c0798c31cf1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.604603 [ 3863 ] {dd7f5ce5-b5ff-4caf-8c4a-70498d3400e0} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTime32BestEffortOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.605944 [ 3863 ] {dd7f5ce5-b5ff-4caf-8c4a-70498d3400e0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.626333 [ 3863 ] {82a85ece-ec3b-47ea-b38b-dc2d7769387d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTime64BestEffort([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.627845 [ 3863 ] {82a85ece-ec3b-47ea-b38b-dc2d7769387d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:06.648091 [ 3863 ] {1682909d-7c7a-49dd-b0bc-9f3fceca9acb} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTime64BestEffortOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.649373 [ 3863 ] {1682909d-7c7a-49dd-b0bc-9f3fceca9acb} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:06.730145 [ 3863 ] {e2e4054c-e470-4e62-99d4-d7ded3da2e5d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTime64BestEffortOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.731456 [ 3863 ] {e2e4054c-e470-4e62-99d4-d7ded3da2e5d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:06.750797 [ 3863 ] {f6aff800-fbdc-44b3-bbbe-76915c22f5ca} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUS([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTime64BestEffortUS([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.752002 [ 3863 ] {f6aff800-fbdc-44b3-bbbe-76915c22f5ca} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUS([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:06.772131 [ 3863 ] {2eee9026-1f87-4966-b06d-694d64710b19} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUSOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTime64BestEffortUSOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.773301 [ 3863 ] {2eee9026-1f87-4966-b06d-694d64710b19} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUSOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:06.792399 [ 3863 ] {5dc591fa-ed23-44fd-a00c-456eef699cca} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUSOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTime64BestEffortUSOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.793613 [ 3863 ] {5dc591fa-ed23-44fd-a00c-456eef699cca} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTime64BestEffortUSOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:06.812501 [ 3863 ] {3d753085-34e9-4e41-b753-67b229895ac6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffort'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTimeBestEffort([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.813784 [ 3863 ] {3d753085-34e9-4e41-b753-67b229895ac6} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffort'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffort([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:06.831218 [ 3863 ] {65d04b10-4abb-4af8-8e80-12a3a90a3a94} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffortOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTimeBestEffortOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.832565 [ 3863 ] {65d04b10-4abb-4af8-8e80-12a3a90a3a94} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffortOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:06.851014 [ 3863 ] {8a6dc92e-194c-4863-98c6-b5226b0e3e38} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffortOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTimeBestEffortOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.852242 [ 3863 ] {8a6dc92e-194c-4863-98c6-b5226b0e3e38} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTimeBestEffortOrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeBestEffortOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:06.885113 [ 4734 ] {e5491381-8241-47f0-a58c-c060faae98ae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37554) (comment: 01160_table_dependencies.sh) (in query: attach database test_krdjlok0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseOnDisk::iterateMetadataFiles(std::shared_ptr, std::function const&) const @ 0x0000000032959b14 7. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:0: DB::DatabaseOrdinary::loadTablesMetadata(std::shared_ptr, DB::ParsedTablesMetadata&, bool) @ 0x00000000329b7366 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349031b0 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:01:06.886566 [ 4734 ] {e5491381-8241-47f0-a58c-c060faae98ae} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseOnDisk::iterateMetadataFiles(std::shared_ptr, std::function const&) const @ 0x0000000032959b14 7. ./build_docker/./src/Databases/DatabaseOrdinary.cpp:0: DB::DatabaseOrdinary::loadTablesMetadata(std::shared_ptr, DB::ParsedTablesMetadata&, bool) @ 0x00000000329b7366 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000349031b0 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000034883458 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:01:06.943650 [ 3863 ] {34b89ecc-9773-4fd1-861f-f2ccd7795199} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTimeBestEffortUS([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.945227 [ 3863 ] {34b89ecc-9773-4fd1-861f-f2ccd7795199} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.971149 [ 3863 ] {09791060-95f0-4918-b5cb-2068df2c0412} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTimeBestEffortUSOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.972534 [ 3863 ] {09791060-95f0-4918-b5cb-2068df2c0412} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:06.992079 [ 3863 ] {2913c0c2-0fb7-4b22-89b0-d95101b34c4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTimeBestEffortUSOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:06.993396 [ 3863 ] {2913c0c2-0fb7-4b22-89b0-d95101b34c4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.010324 [ 3863 ] {c636427a-c1a5-4883-88b1-98e7948453e8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTimeInJodaSyntax([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.011477 [ 3863 ] {c636427a-c1a5-4883-88b1-98e7948453e8} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntax([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:07.028804 [ 3863 ] {f7cdae29-95fb-40d1-9b51-419fb7ddb482} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntaxOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTimeInJodaSyntaxOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.030096 [ 3863 ] {f7cdae29-95fb-40d1-9b51-419fb7ddb482} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntaxOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:07.127554 [ 3863 ] {2fe76309-4489-4314-9d91-53d4daca90bf} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntaxOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTimeInJodaSyntaxOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.129065 [ 3863 ] {2fe76309-4489-4314-9d91-53d4daca90bf} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeInJodaSyntaxOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:07.150116 [ 3863 ] {98156cd2-0bda-45f4-9be4-7195ab3e3a56} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTimeOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.151451 [ 3863 ] {98156cd2-0bda-45f4-9be4-7195ab3e3a56} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeOrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:07.169271 [ 3863 ] {230af21e-a01c-4bb7-875f-17ba21da7f31} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseDateTimeOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.170739 [ 3863 ] {230af21e-a01c-4bb7-875f-17ba21da7f31} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT parseDateTimeOrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:07.188645 [ 3863 ] {23fa9f1e-0c06-4bfa-9008-1fb0945062ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseReadableSize([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.190019 [ 3863 ] {23fa9f1e-0c06-4bfa-9008-1fb0945062ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 3, should be 1: In scope SELECT parseReadableSize([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.207476 [ 3863 ] {2db22400-e3ed-40cb-8a1f-397b3f5e1b24} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseReadableSizeOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.208699 [ 3863 ] {2db22400-e3ed-40cb-8a1f-397b3f5e1b24} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.225886 [ 3863 ] {61dba32d-8304-4d82-bc33-77bcf9d101cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseReadableSizeOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.227180 [ 3863 ] {61dba32d-8304-4d82-bc33-77bcf9d101cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 3, should be 1: In scope SELECT parseReadableSizeOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.245337 [ 3863 ] {6e98d0a1-d990-436b-9b48-2639649666d1} executeQuery: Code: 34. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 3, should be 1.: In scope SELECT parseTimeDelta([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT parseTimeDelta([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.246971 [ 3863 ] {6e98d0a1-d990-436b-9b48-2639649666d1} TCPHandler: Code: 34. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 3, should be 1.: In scope SELECT parseTimeDelta([NULL], [NULL], [NULL]). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:01:07.322912 [ 3863 ] {f0150cc7-4bf9-4edc-b02d-8bc800974e01} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT path([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.324153 [ 3863 ] {f0150cc7-4bf9-4edc-b02d-8bc800974e01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 3, should be 1: In scope SELECT path([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.344639 [ 3863 ] {85f5b774-be06-4341-af0f-61a56f03e621} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT pathFull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.345964 [ 3863 ] {85f5b774-be06-4341-af0f-61a56f03e621} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 3, should be 1: In scope SELECT pathFull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.376409 [ 3863 ] {19012c18-6b0e-4c60-9506-f5c9907c35b8} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT percentRank([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.378270 [ 3863 ] {19012c18-6b0e-4c60-9506-f5c9907c35b8} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.03.31 19:01:07.408375 [ 3863 ] {f4cd669f-8b33-4d88-956c-6966248983d6} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT percent_rank([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.410142 [ 3863 ] {f4cd669f-8b33-4d88-956c-6966248983d6} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.03.31 19:01:07.429453 [ 3863 ] {c3016100-576f-4196-8090-2e2f60defb31} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT pi([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.430976 [ 3863 ] {c3016100-576f-4196-8090-2e2f60defb31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 3, should be 0: In scope SELECT pi([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.451773 [ 3863 ] {a3108fbb-e87c-42be-ba0a-f2e11b3310b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT plus([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.453318 [ 3863 ] {a3108fbb-e87c-42be-ba0a-f2e11b3310b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 3, should be 2: In scope SELECT plus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.473084 [ 3863 ] {bbdc4264-975e-465a-ab82-2422248e9c10} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT pmod([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.474426 [ 3863 ] {bbdc4264-975e-465a-ab82-2422248e9c10} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT pmod([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.495209 [ 3863 ] {99a959fe-5b3b-4b3b-93d9-d146eda097c7} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT pointInEllipses([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.496901 [ 3863 ] {99a959fe-5b3b-4b3b-93d9-d146eda097c7} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.517098 [ 3863 ] {5b3da271-f6c0-4147-bfd5-4c25e504875b} executeQuery: Code: 43. DB::Exception: Argument 1 for function pointInPolygon must contain a tuple: In scope SELECT pointInPolygon([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT pointInPolygon([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.518417 [ 3863 ] {5b3da271-f6c0-4147-bfd5-4c25e504875b} TCPHandler: Code: 43. DB::Exception: Argument 1 for function pointInPolygon must contain a tuple: In scope SELECT pointInPolygon([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:07.535495 [ 3863 ] {87d93f46-099a-4bcb-b758-a76413a2e670} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonAreaCartesian([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.536666 [ 3863 ] {87d93f46-099a-4bcb-b758-a76413a2e670} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonAreaCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.553905 [ 3863 ] {7c2a15f3-618a-4750-b7b5-d782f735798d} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonAreaSpherical([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.555048 [ 3863 ] {7c2a15f3-618a-4750-b7b5-d782f735798d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonAreaSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.572698 [ 3863 ] {6e559a55-ec6f-4a0f-b7a2-9e4a690c0975} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonConvexHullCartesian([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.574077 [ 3863 ] {6e559a55-ec6f-4a0f-b7a2-9e4a690c0975} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonConvexHullCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.626344 [ 3863 ] {17129532-087b-4059-8cbf-654b4fbf1ef5} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonPerimeterCartesian([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.627947 [ 3863 ] {17129532-087b-4059-8cbf-654b4fbf1ef5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.648379 [ 3863 ] {c7865083-00ec-44b9-bbd6-1eab69667b79} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonPerimeterSpherical([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.649933 [ 3863 ] {c7865083-00ec-44b9-bbd6-1eab69667b79} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 3, should be 1: In scope SELECT polygonPerimeterSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.667341 [ 3863 ] {338f605e-f91e-4f81-a2ee-cb25328c38dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonsDistanceCartesian([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.668597 [ 3863 ] {338f605e-f91e-4f81-a2ee-cb25328c38dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.686898 [ 3863 ] {c3a0c030-816e-4bca-8f88-72f870270997} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonsDistanceSpherical([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.688316 [ 3863 ] {c3a0c030-816e-4bca-8f88-72f870270997} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsDistanceSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.708339 [ 3863 ] {07deb7cf-1233-4d51-9619-63dc47d7da28} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonsEqualsCartesian([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.709693 [ 3863 ] {07deb7cf-1233-4d51-9619-63dc47d7da28} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsEqualsCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.730237 [ 3863 ] {d22d310a-5485-4e10-81a8-688b0d486cab} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonsIntersectionCartesian([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.731532 [ 3863 ] {d22d310a-5485-4e10-81a8-688b0d486cab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.748454 [ 3863 ] {e65dd365-593f-4ee4-b306-b1b580c7a053} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonsIntersectionSpherical([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.749670 [ 3863 ] {e65dd365-593f-4ee4-b306-b1b580c7a053} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsIntersectionSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.858645 [ 3863 ] {f7a21a8d-aacd-4751-9996-7edac5bd5719} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonsSymDifferenceCartesian([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.859999 [ 3863 ] {f7a21a8d-aacd-4751-9996-7edac5bd5719} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.880768 [ 3863 ] {95853269-cf68-4097-b613-101a8eec7add} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonsSymDifferenceSpherical([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.882160 [ 3863 ] {95853269-cf68-4097-b613-101a8eec7add} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsSymDifferenceSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.901993 [ 3863 ] {4c2821f0-b63e-4236-8472-2467ced62e80} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonsUnionCartesian([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.903288 [ 3863 ] {4c2821f0-b63e-4236-8472-2467ced62e80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.923322 [ 3863 ] {6be4ab50-03d6-4db0-9c06-9065ccf1a82a} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonsUnionSpherical([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.927393 [ 3863 ] {6be4ab50-03d6-4db0-9c06-9065ccf1a82a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsUnionSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.947418 [ 3863 ] {49a85f15-7f8d-4eaa-b8bb-f8e44a39e5f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonsWithinCartesian([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.948648 [ 3863 ] {49a85f15-7f8d-4eaa-b8bb-f8e44a39e5f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinCartesian([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.966477 [ 3863 ] {b3e1d15e-f2a2-4a02-8d0b-c87ce3041bd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT polygonsWithinSpherical([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.967773 [ 3863 ] {b3e1d15e-f2a2-4a02-8d0b-c87ce3041bd9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 3, should be 2: In scope SELECT polygonsWithinSpherical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:07.986785 [ 3863 ] {6051a16b-d19f-4b06-9f16-c8cccd1273f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 3, should be 1 or 2: In scope SELECT port([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT port([NULL], [NULL], [NULL]);) 2025.03.31 19:01:07.988045 [ 3863 ] {6051a16b-d19f-4b06-9f16-c8cccd1273f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 3, should be 1 or 2: In scope SELECT port([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:08.006819 [ 3863 ] {feb86509-e380-4917-b3c9-3fc234a61ce2} executeQuery: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 3, should be 1 or 2: In scope SELECT portRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT portRFC([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.008133 [ 3863 ] {feb86509-e380-4917-b3c9-3fc234a61ce2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 3, should be 1 or 2: In scope SELECT portRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:08.027605 [ 3863 ] {4dff6654-69df-4285-abc0-888bf069d189} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function position: In scope SELECT position([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT position([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.028816 [ 3863 ] {4dff6654-69df-4285-abc0-888bf069d189} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function position: In scope SELECT position([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.046084 [ 3863 ] {6c6df5eb-cba2-4f0d-bbc1-742cf00ca51e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitive: In scope SELECT positionCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT positionCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.047473 [ 3863 ] {6c6df5eb-cba2-4f0d-bbc1-742cf00ca51e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitive: In scope SELECT positionCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.065418 [ 3863 ] {10b6e784-75e4-4a8b-ab95-21093d5eba83} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitiveUTF8: In scope SELECT positionCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT positionCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.066623 [ 3863 ] {10b6e784-75e4-4a8b-ab95-21093d5eba83} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionCaseInsensitiveUTF8: In scope SELECT positionCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.083417 [ 3863 ] {ab9b845a-ad05-4a38-bbb4-0c21bdacf48d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionUTF8: In scope SELECT positionUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT positionUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.084614 [ 3863 ] {ab9b845a-ad05-4a38-bbb4-0c21bdacf48d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function positionUTF8: In scope SELECT positionUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.101951 [ 3863 ] {792b8a1a-c292-4054-854b-7564802afd3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT positiveModulo([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.103295 [ 3863 ] {792b8a1a-c292-4054-854b-7564802afd3d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positiveModulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:08.120804 [ 3863 ] {ca7190de-d735-43c8-b6c8-688121fd4d8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT positive_modulo([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.122068 [ 3863 ] {ca7190de-d735-43c8-b6c8-688121fd4d8a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 3, should be 2: In scope SELECT positive_modulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:08.235956 [ 3863 ] {a556a701-7bd2-44be-90ca-cdcfc246b77c} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT pow([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.237561 [ 3863 ] {a556a701-7bd2-44be-90ca-cdcfc246b77c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT pow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:08.248308 [ 3831 ] {c6a020d4-11bd-4750-a8ce-940d872f3bec} executeQuery: Code: 81. DB::Exception: Database test_krdjlok0 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37610) (comment: 01160_table_dependencies.sh) (in query: detach database test_krdjlok0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:660: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000003399e03c 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>>>&) @ 0x000000003492f1df 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:01:08.257235 [ 3863 ] {d67d9175-06c2-4458-8549-baf5659bc4ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT power([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.258811 [ 3863 ] {d67d9175-06c2-4458-8549-baf5659bc4ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 3, should be 2: In scope SELECT power([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:08.279045 [ 3863 ] {9000b556-b9b7-4750-9940-d66ac2d0eac4} executeQuery: Code: 43. DB::Exception: The first argument type of function printf is Array(Nullable(Nothing)), but String type is expected: In scope SELECT printf([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT printf([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.280546 [ 3863 ] {9000b556-b9b7-4750-9940-d66ac2d0eac4} TCPHandler: Code: 43. DB::Exception: The first argument type of function printf is Array(Nullable(Nothing)), but String type is expected: In scope SELECT printf([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.292278 [ 3831 ] {c6a020d4-11bd-4750-a8ce-940d872f3bec} TCPHandler: Code: 81. DB::Exception: Database test_krdjlok0 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:660: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000003399e03c 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>>>&) @ 0x000000003492f1df 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:01:08.298226 [ 3863 ] {65979195-d9ef-448a-b358-e9b3684d6b75} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT proportionsZTest([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.299474 [ 3863 ] {65979195-d9ef-448a-b358-e9b3684d6b75} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 3, should be 6: In scope SELECT proportionsZTest([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:08.316450 [ 3863 ] {c74c7711-436a-4bc5-8e1a-7c1b0afac073} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT protocol([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.317652 [ 3863 ] {c74c7711-436a-4bc5-8e1a-7c1b0afac073} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 3, should be 1: In scope SELECT protocol([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:08.335485 [ 3863 ] {5374fb17-914e-4e5e-930f-dc7f3e9b6973} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT punycodeDecode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.336717 [ 3863 ] {5374fb17-914e-4e5e-930f-dc7f3e9b6973} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 3, should be 1: In scope SELECT punycodeDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:08.337525 [ 3830 ] {21544150-7341-4910-b742-7e6fcf978fb1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x00000000083fea57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8cc9 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:01:08.338316 [ 3830 ] {21544150-7341-4910-b742-7e6fcf978fb1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x00000000083fea57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8cc9 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:01:08.354555 [ 3863 ] {3eff58e3-c316-4fd4-8090-822dea425a51} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT punycodeEncode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.355694 [ 3863 ] {3eff58e3-c316-4fd4-8090-822dea425a51} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 3, should be 1: In scope SELECT punycodeEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:08.374913 [ 3863 ] {4d094dc2-909d-4cd9-bda6-935f4dc01171} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantile([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.376156 [ 3863 ] {4d094dc2-909d-4cd9-bda6-935f4dc01171} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.395006 [ 3863 ] {301cd11a-9f0d-4ad0-b4ba-2d317bad9f98} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileBFloat16([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.396402 [ 3863 ] {301cd11a-9f0d-4ad0-b4ba-2d317bad9f98} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.417448 [ 3863 ] {292c878c-df96-4637-a629-9cebf6b6523a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileBFloat16Weighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.418940 [ 3863 ] {292c878c-df96-4637-a629-9cebf6b6523a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.437151 [ 3863 ] {b589ef5f-cd0f-41de-87e3-ec7fdd8912b0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileDD([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.438666 [ 3863 ] {b589ef5f-cd0f-41de-87e3-ec7fdd8912b0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.457942 [ 3863 ] {17e9b805-9b62-4eaf-9d40-1f04ab0ef9f2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileDeterministic([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.459166 [ 3863 ] {17e9b805-9b62-4eaf-9d40-1f04ab0ef9f2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.476146 [ 3863 ] {7092ebb4-74a6-4d94-a277-d73712bef485} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileExact([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.477528 [ 3863 ] {7092ebb4-74a6-4d94-a277-d73712bef485} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.495035 [ 3863 ] {1684c75c-4dc7-4889-a3bf-6e9a49f0a369} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileExactExclusive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.496153 [ 3863 ] {1684c75c-4dc7-4889-a3bf-6e9a49f0a369} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.513586 [ 3863 ] {060f17b9-aa92-46be-940b-67a1f72cd03d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileExactHigh([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.514754 [ 3863 ] {060f17b9-aa92-46be-940b-67a1f72cd03d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.530664 [ 3863 ] {76ca4728-b216-4642-864a-0a43dea198fc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileExactInclusive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.531889 [ 3863 ] {76ca4728-b216-4642-864a-0a43dea198fc} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.594828 [ 3863 ] {b134c788-7c7e-4fbb-afbc-0027cdf09e92} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileExactLow([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.596888 [ 3863 ] {b134c788-7c7e-4fbb-afbc-0027cdf09e92} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.621920 [ 3863 ] {d237f103-741f-44fa-82d2-d25058485b89} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileExactWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.623665 [ 3863 ] {d237f103-741f-44fa-82d2-d25058485b89} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.644093 [ 3863 ] {b0828ae1-5223-41d7-bdd1-071848500c6f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileGK([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.646013 [ 3863 ] {b0828ae1-5223-41d7-bdd1-071848500c6f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.664556 [ 3863 ] {ac50fc73-a741-4a49-8a50-5ac93b6d4e1c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileInterpolatedWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.712698 [ 3863 ] {ac50fc73-a741-4a49-8a50-5ac93b6d4e1c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.731062 [ 3863 ] {e46bcbab-8040-44b4-93bf-f0e6657ab9fd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileTDigest([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.732298 [ 3863 ] {e46bcbab-8040-44b4-93bf-f0e6657ab9fd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.750895 [ 3863 ] {844ddb64-a361-4749-abdb-ffc567f021db} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileTDigestWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.752349 [ 3863 ] {844ddb64-a361-4749-abdb-ffc567f021db} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.770813 [ 3863 ] {0e8ad812-a815-4422-8526-8de8d9573d9d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileTiming([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.772168 [ 3863 ] {0e8ad812-a815-4422-8526-8de8d9573d9d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.802626 [ 3863 ] {3821f3c2-c8d8-457e-b2bb-fe7b9cafcc67} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantileTimingWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.804023 [ 3863 ] {3821f3c2-c8d8-457e-b2bb-fe7b9cafcc67} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.822689 [ 3863 ] {eebf20e8-e203-48a0-ae30-2a7f23a6653b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantiles([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.824331 [ 3863 ] {eebf20e8-e203-48a0-ae30-2a7f23a6653b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.842196 [ 3863 ] {4d715859-c463-4996-b0e8-590d9b5716c5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesBFloat16([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.843410 [ 3863 ] {4d715859-c463-4996-b0e8-590d9b5716c5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.859866 [ 3863 ] {34c24cf3-8c29-4fdf-a2b0-c8ca7df88cc8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesBFloat16Weighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.861269 [ 3863 ] {34c24cf3-8c29-4fdf-a2b0-c8ca7df88cc8} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.877093 [ 3863 ] {e2f7bf13-ff42-4c58-8ee0-04d1af318371} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesDD([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.878616 [ 3863 ] {e2f7bf13-ff42-4c58-8ee0-04d1af318371} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:08.894873 [ 3863 ] {7e0a6a38-95a0-4444-90c7-dbaf6b425d42} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesDeterministic([NULL], [NULL], [NULL]);) 2025.03.31 19:01:08.896088 [ 3863 ] {7e0a6a38-95a0-4444-90c7-dbaf6b425d42} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.013301 [ 3863 ] {2697eb27-68be-4d7f-972c-461b2ad302d6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesExact([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.015605 [ 3863 ] {2697eb27-68be-4d7f-972c-461b2ad302d6} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.039683 [ 3863 ] {7e33ebd2-e334-45ae-a35a-78f67e92dd0c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesExactExclusive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.042161 [ 3863 ] {7e33ebd2-e334-45ae-a35a-78f67e92dd0c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.073597 [ 3863 ] {8fcbe373-5d0e-4fd1-a1e9-e9056c34f07e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesExactHigh([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.075243 [ 3863 ] {8fcbe373-5d0e-4fd1-a1e9-e9056c34f07e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.096129 [ 3863 ] {4f6fddba-04cd-41a0-99df-98f4e707f1e8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesExactInclusive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.097625 [ 3863 ] {4f6fddba-04cd-41a0-99df-98f4e707f1e8} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.199635 [ 3863 ] {8aae190f-0eee-4035-b7d7-258ffc570419} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesExactLow([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.201148 [ 3863 ] {8aae190f-0eee-4035-b7d7-258ffc570419} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.219008 [ 3863 ] {61dd7867-b6fd-4fc6-9322-4ef09ff12868} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesExactWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.220301 [ 3863 ] {61dd7867-b6fd-4fc6-9322-4ef09ff12868} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.259961 [ 3863 ] {fe42f6c3-cb1b-4af0-8d46-c8477a906caa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesGK([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.261548 [ 3863 ] {fe42f6c3-cb1b-4af0-8d46-c8477a906caa} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.279870 [ 3863 ] {3c9e3e08-b9e3-42d3-b794-7d8a1d29d5ad} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesInterpolatedWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.281206 [ 3863 ] {3c9e3e08-b9e3-42d3-b794-7d8a1d29d5ad} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.377027 [ 3863 ] {eabf1e3b-568f-483e-a551-57f552640a8c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesTDigest([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.432080 [ 3863 ] {eabf1e3b-568f-483e-a551-57f552640a8c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.451642 [ 3863 ] {b0d40e5f-ba80-4d56-8e77-daf1bc1479ee} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesTDigestWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.453024 [ 3863 ] {b0d40e5f-ba80-4d56-8e77-daf1bc1479ee} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.472542 [ 3863 ] {2b79c855-0759-480a-bb1e-647b657d9679} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesTiming([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.560661 [ 3863 ] {2b79c855-0759-480a-bb1e-647b657d9679} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.581184 [ 3863 ] {06d0d3ed-9c6a-471a-a1d6-fc636e34c4d3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT quantilesTimingWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.582831 [ 3863 ] {06d0d3ed-9c6a-471a-a1d6-fc636e34c4d3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:09.602523 [ 3863 ] {46c07dfb-eee8-4fac-8d66-d842c26db910} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT queryID([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.603692 [ 3863 ] {46c07dfb-eee8-4fac-8d66-d842c26db910} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT queryID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:09.622893 [ 3863 ] {a25b0e4f-f191-4dfe-8b8d-6c03861766a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT queryString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.624202 [ 3863 ] {a25b0e4f-f191-4dfe-8b8d-6c03861766a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 3, should be 1: In scope SELECT queryString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:09.640982 [ 3863 ] {e1214cee-b256-4298-9cb3-b1b90f250116} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT queryStringAndFragment([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.642371 [ 3863 ] {e1214cee-b256-4298-9cb3-b1b90f250116} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 3, should be 1: In scope SELECT queryStringAndFragment([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:09.719137 [ 3863 ] {de4ab63d-69a8-42d1-b637-f5601853d98f} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT query_id([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.720446 [ 3863 ] {de4ab63d-69a8-42d1-b637-f5601853d98f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 3, should be 0: In scope SELECT query_id([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:09.736708 [ 3863 ] {44c72c93-4b62-4c5e-b694-1a11113f60b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT radians([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.831764 [ 3863 ] {44c72c93-4b62-4c5e-b694-1a11113f60b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 3, should be 1: In scope SELECT radians([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:09.853851 [ 3863 ] {2c2a8925-ce0e-4025-aa57-35613d26f86b} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT rand([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.855451 [ 3863 ] {2c2a8925-ce0e-4025-aa57-35613d26f86b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:09.875224 [ 3863 ] {c2799dd1-7e38-4bec-b6e4-203f2f9b7cb3} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT rand32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.876611 [ 3863 ] {c2799dd1-7e38-4bec-b6e4-203f2f9b7cb3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:09.897382 [ 3863 ] {f44ceb87-be0f-4e37-a673-4c23079cead8} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT rand64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:09.898957 [ 3863 ] {f44ceb87-be0f-4e37-a673-4c23079cead8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 3, should be 0 or 1.: In scope SELECT rand64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.004282 [ 3863 ] {3f0d1ba2-88f5-4145-9bda-717b1d6687b3} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randBernoulli([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.006048 [ 3863 ] {3f0d1ba2-88f5-4145-9bda-717b1d6687b3} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.026865 [ 3863 ] {035012ed-c3f2-42e1-ad64-aba6ad582353} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randBinomial, expected Float64 or integer: In scope SELECT randBinomial([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randBinomial([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.028247 [ 3863 ] {035012ed-c3f2-42e1-ad64-aba6ad582353} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randBinomial, expected Float64 or integer: In scope SELECT randBinomial([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:10.040613 [ 4734 ] {d8b856cf-a07c-427c-83c1-82a73996a3ea} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=721). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37616) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 103918;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:10.047204 [ 3863 ] {eb8f039a-7193-456a-9cbe-2b7990aa3b60} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randCanonical([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.048589 [ 3863 ] {eb8f039a-7193-456a-9cbe-2b7990aa3b60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 3, should be 0 or 1.: In scope SELECT randCanonical([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.060365 [ 3830 ] {02ee6103-cfef-408f-8188-0ffcc98e70b2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDate('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:10.061594 [ 3830 ] {02ee6103-cfef-408f-8188-0ffcc98e70b2} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:10.104768 [ 4734 ] {d8b856cf-a07c-427c-83c1-82a73996a3ea} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:10.122429 [ 3863 ] {202a504c-4f4f-4321-80e1-c47a21e59b03} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randChiSquared([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.123366 [ 3830 ] {5f998aa8-b49b-47e1-ab36-8ef6f723408c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDate32('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:10.123802 [ 3863 ] {202a504c-4f4f-4321-80e1-c47a21e59b03} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.124371 [ 3830 ] {5f998aa8-b49b-47e1-ab36-8ef6f723408c} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:10.137362 [ 3830 ] {b68c7a40-7a0c-47df-9d28-2299123a093c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDateTime('2023-09-11 12:18:00'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:10.138541 [ 3830 ] {b68c7a40-7a0c-47df-9d28-2299123a093c} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:10.142191 [ 3863 ] {41aea748-e01e-4464-b005-04879d1461b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randConstant([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.143368 [ 3863 ] {41aea748-e01e-4464-b005-04879d1461b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 3, should be 0 or 1.: In scope SELECT randConstant([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.159458 [ 3831 ] {559db1f5-cfa7-436f-9d34-ac4a3dd67c89} executeQuery: Code: 57. DB::Exception: Table test_5.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00163_column_oriented_formats.sh) (in query: /* ddl_entry=query-0000000014 */ CREATE TABLE test_5.`00163_column_oriented` UUID '8108d77e-d7e8-44f6-9170-869de3e14e17' (`ClientEventTime` DateTime('Asia/Dubai'), `MobilePhoneModel` String, `ClientIP6` FixedString(16)) ENGINE = File(ORC)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:01:10.162964 [ 3863 ] {1e6d8923-963d-45a8-b5fc-64c0127cc967} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randExponential([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.164169 [ 3863 ] {1e6d8923-963d-45a8-b5fc-64c0127cc967} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.181265 [ 3863 ] {9c41077c-8c31-4d67-898d-b7abcc1d804f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randFisherF, expected Float64 or integer: In scope SELECT randFisherF([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randFisherF([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.200607 [ 3830 ] {ac864407-6dd1-49a7-b1fc-cced4ae82335} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(toDateTime64('2023-09-11 12:18:00', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:10.201568 [ 3830 ] {ac864407-6dd1-49a7-b1fc-cced4ae82335} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:10.202478 [ 3863 ] {9c41077c-8c31-4d67-898d-b7abcc1d804f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randFisherF, expected Float64 or integer: In scope SELECT randFisherF([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:10.214574 [ 3830 ] {434bf42f-5af1-4088-925f-2383f25788d7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime('2023-09-11');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:10.215569 [ 3830 ] {434bf42f-5af1-4088-925f-2383f25788d7} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:10.222298 [ 3863 ] {0d4fad7a-2864-4f36-91b6-f7bf16e9479d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randLogNormal, expected Float64 or integer: In scope SELECT randLogNormal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randLogNormal([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.223818 [ 3863 ] {0d4fad7a-2864-4f36-91b6-f7bf16e9479d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randLogNormal, expected Float64 or integer: In scope SELECT randLogNormal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:10.231682 [ 3831 ] {559db1f5-cfa7-436f-9d34-ac4a3dd67c89} executeQuery: Code: 57. DB::Exception: Table test_5.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51130) (comment: 00163_column_oriented_formats.sh) (in query: CREATE TABLE 00163_column_oriented(ClientEventTime DateTime('Asia/Dubai'), MobilePhoneModel String, ClientIP6 FixedString(16)) ENGINE=File(ORC)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:01:10.233263 [ 3831 ] {559db1f5-cfa7-436f-9d34-ac4a3dd67c89} TCPHandler: Code: 57. DB::Exception: Table test_5.`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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003394fdde 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000339490ec 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000032ac794d 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000032a4311c 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb224 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:01:10.242600 [ 3863 ] {5e78f02d-4164-49a0-9126-4b8de34ab580} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randNegativeBinomial, expected Float64 or integer: In scope SELECT randNegativeBinomial([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randNegativeBinomial([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.244197 [ 3863 ] {5e78f02d-4164-49a0-9126-4b8de34ab580} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randNegativeBinomial, expected Float64 or integer: In scope SELECT randNegativeBinomial([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:10.262439 [ 3863 ] {2986442d-c75d-4107-9750-2f6768464c34} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randNormal, expected Float64 or integer: In scope SELECT randNormal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randNormal([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.263916 [ 3863 ] {2986442d-c75d-4107-9750-2f6768464c34} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randNormal, expected Float64 or integer: In scope SELECT randNormal([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:10.282129 [ 3863 ] {855979b8-16b6-440e-9420-4632d1ea2c41} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randPoisson([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.283643 [ 3863 ] {855979b8-16b6-440e-9420-4632d1ea2c41} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.301487 [ 3863 ] {d6b148c8-a317-41eb-81a1-9b68f9d0c6cb} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randStudentT([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.302913 [ 3863 ] {d6b148c8-a317-41eb-81a1-9b68f9d0c6cb} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.319961 [ 3863 ] {34d69fa0-5fdf-4deb-8e01-8179348cf046} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randUniform, expected Float64 or integer: In scope SELECT randUniform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randUniform([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.321280 [ 3863 ] {34d69fa0-5fdf-4deb-8e01-8179348cf046} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function randUniform, expected Float64 or integer: In scope SELECT randUniform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:10.394785 [ 3863 ] {c93c6892-d453-4dfb-9a57-baf8a89ebe3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randomFixedString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.396189 [ 3863 ] {c93c6892-d453-4dfb-9a57-baf8a89ebe3d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 3, should be 1: In scope SELECT randomFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.414155 [ 3863 ] {4beb830b-6ecf-4676-ac60-02e965a67507} executeQuery: Code: 42. DB::Exception: Function randomPrintableASCII requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomPrintableASCII([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randomPrintableASCII([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.415367 [ 3863 ] {4beb830b-6ecf-4676-ac60-02e965a67507} TCPHandler: Code: 42. DB::Exception: Function randomPrintableASCII requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomPrintableASCII([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.434918 [ 3863 ] {48d0b8f2-c8a3-4cea-a870-3854c96a5d38} executeQuery: Code: 42. DB::Exception: Function randomString requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randomString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.436246 [ 3863 ] {48d0b8f2-c8a3-4cea-a870-3854c96a5d38} TCPHandler: Code: 42. DB::Exception: Function randomString requires at most two arguments: the size of resulting string and optional disambiguation tag: In scope SELECT randomString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.455112 [ 3863 ] {d96d4cab-197d-4968-8256-46c27fc4a66e} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT randomStringUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.456628 [ 3863 ] {d96d4cab-197d-4968-8256-46c27fc4a66e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 3, should be 1: In scope SELECT randomStringUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.475828 [ 3863 ] {9b6a31f0-79c4-4b54-8c24-83ecd5e04da3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function range: In scope SELECT range([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT range([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.477518 [ 3863 ] {9b6a31f0-79c4-4b54-8c24-83ecd5e04da3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function range: In scope SELECT range([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:10.506398 [ 3863 ] {fa4749dc-49c6-4395-bce2-4340eb878a14} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT rank([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.509032 [ 3863 ] {fa4749dc-49c6-4395-bce2-4340eb878a14} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.03.31 19:01:10.530493 [ 3863 ] {03d5b7a3-0cc7-471c-82a1-da20a6f7a2fd} executeQuery: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT rankCorr([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.532128 [ 3863 ] {03d5b7a3-0cc7-471c-82a1-da20a6f7a2fd} TCPHandler: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.552249 [ 3863 ] {8880d77c-aa4c-480f-8d53-d5ba96a43f37} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT readWKTLineString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.586257 [ 3863 ] {8880d77c-aa4c-480f-8d53-d5ba96a43f37} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTLineString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.603814 [ 3863 ] {6cec96bb-b3c5-4e68-9ce0-45d2350578f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT readWKTMultiLineString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.604983 [ 3863 ] {6cec96bb-b3c5-4e68-9ce0-45d2350578f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiLineString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.622315 [ 3863 ] {fa08e81c-a4d0-49fd-8e06-40108878a391} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT readWKTMultiPolygon([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.623603 [ 3863 ] {fa08e81c-a4d0-49fd-8e06-40108878a391} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTMultiPolygon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.639873 [ 3863 ] {2cde3adc-9a73-43b7-a7a1-6e79af65f6a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT readWKTPoint([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.641017 [ 3863 ] {2cde3adc-9a73-43b7-a7a1-6e79af65f6a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 3, should be 1: In scope SELECT readWKTPoint([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.656015 [ 3863 ] {89dfa040-1758-4f8a-a25e-1be7c26b868c} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT readWKTPolygon([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.657329 [ 3863 ] {89dfa040-1758-4f8a-a25e-1be7c26b868c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 3, should be 1: In scope SELECT readWKTPolygon([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.675294 [ 3863 ] {538c945a-9e99-4c6b-9163-1615a490f822} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT readWKTRing([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.676512 [ 3863 ] {538c945a-9e99-4c6b-9163-1615a490f822} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 3, should be 1: In scope SELECT readWKTRing([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.691884 [ 3863 ] {9026d6a3-77e1-4f31-aa9a-9bae61114959} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT regexpExtract([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regexpExtract([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.693065 [ 3863 ] {9026d6a3-77e1-4f31-aa9a-9bae61114959} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT regexpExtract([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:10.794722 [ 3863 ] {a40dfcbb-30d2-4b86-a6e8-a4e00777eb15} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regexpQuoteMeta([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.796215 [ 3863 ] {a40dfcbb-30d2-4b86-a6e8-a4e00777eb15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 3, should be 1: In scope SELECT regexpQuoteMeta([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.823277 [ 3863 ] {70bf2b5d-d38d-4fad-b20c-793919f4a9d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regionHierarchy([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.824809 [ 3863 ] {70bf2b5d-d38d-4fad-b20c-793919f4a9d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionHierarchy([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.841409 [ 3863 ] {faec3fc1-51fe-49e1-9785-c89e4a288b67} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function regionIn (must be UInt32): In scope SELECT regionIn([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regionIn([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.842899 [ 3863 ] {faec3fc1-51fe-49e1-9785-c89e4a288b67} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function regionIn (must be UInt32): In scope SELECT regionIn([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:10.859136 [ 3863 ] {c469625d-7418-4918-923e-9ae163dd8248} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToArea([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regionToArea([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.860461 [ 3863 ] {c469625d-7418-4918-923e-9ae163dd8248} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToArea([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.893587 [ 3863 ] {85cb8fcb-36d6-4335-a08d-290b493e47bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regionToCity([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.895115 [ 3863 ] {85cb8fcb-36d6-4335-a08d-290b493e47bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCity([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:10.911902 [ 3863 ] {d32be403-5339-48e6-b38e-7e32642dce96} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToContinent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regionToContinent([NULL], [NULL], [NULL]);) 2025.03.31 19:01:10.913195 [ 3863 ] {d32be403-5339-48e6-b38e-7e32642dce96} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToContinent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.011457 [ 3863 ] {28fcf283-ed18-41e0-a38e-e599b5d24e16} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCountry([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regionToCountry([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.013440 [ 3863 ] {28fcf283-ed18-41e0-a38e-e599b5d24e16} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToCountry([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.032455 [ 3863 ] {feb08250-c482-4a70-a4a7-17b4c6906415} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToDistrict([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regionToDistrict([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.033769 [ 3863 ] {feb08250-c482-4a70-a4a7-17b4c6906415} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToDistrict([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.052549 [ 3863 ] {101aa1d1-cf55-4f0b-b425-3086168fc2f3} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regionToName([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.054140 [ 3863 ] {101aa1d1-cf55-4f0b-b425-3086168fc2f3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.072413 [ 3863 ] {bc1bc531-6045-4e17-9ce7-2a9ee96e6db0} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToPopulation([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regionToPopulation([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.073648 [ 3863 ] {bc1bc531-6045-4e17-9ce7-2a9ee96e6db0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToPopulation([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.077614 [ 4734 ] {216da6f6-73de-448b-9cc2-bcb835ef3025} 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.10457.altinitytest (altinity build)) (from [::1]:51162) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832b4f7 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&) @ 0x000000003ba5a50f 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*) @ 0x0000000034b91a81 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&) @ 0x0000000034b94a8f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:11.079166 [ 4734 ] {216da6f6-73de-448b-9cc2-bcb835ef3025} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003832b4f7 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&) @ 0x000000003ba5a50f 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*) @ 0x0000000034b91a81 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&) @ 0x0000000034b94a8f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:11.089876 [ 3863 ] {99634162-9f2b-4f5e-bd0d-4fb320f2266c} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToTopContinent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT regionToTopContinent([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.091194 [ 3863 ] {99634162-9f2b-4f5e-bd0d-4fb320f2266c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 3, should be 1 or 2.: In scope SELECT regionToTopContinent([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.107739 [ 3863 ] {50bde720-3d4d-4365-9aae-cc2f518fdce7} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpret([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.108910 [ 3863 ] {50bde720-3d4d-4365-9aae-cc2f518fdce7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 3, should be 2: In scope SELECT reinterpret([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.187178 [ 3863 ] {749e6716-0312-465c-8835-4f2402f03218} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsDate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.188633 [ 3863 ] {749e6716-0312-465c-8835-4f2402f03218} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.206179 [ 3863 ] {2a561a7f-e9d6-4b89-bba4-0476c477ac03} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.207744 [ 3863 ] {2a561a7f-e9d6-4b89-bba4-0476c477ac03} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.224287 [ 3863 ] {dc709e85-81d4-406b-b3b1-3072a3d787ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsFixedString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.225476 [ 3863 ] {dc709e85-81d4-406b-b3b1-3072a3d787ba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.241928 [ 3863 ] {9875179b-8303-46cf-866d-10376db37965} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsFloat32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.243102 [ 3863 ] {9875179b-8303-46cf-866d-10376db37965} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.258777 [ 3863 ] {2027e9ae-627b-40fc-b00d-5efd0b535a3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsFloat64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.259920 [ 3863 ] {2027e9ae-627b-40fc-b00d-5efd0b535a3d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.356193 [ 3863 ] {af3cb452-683d-4520-bd96-fe258e078eb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsInt128([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.357522 [ 3863 ] {af3cb452-683d-4520-bd96-fe258e078eb0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.376384 [ 3863 ] {d0381b1b-f566-431a-899e-7b3988aadb4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsInt16([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.378066 [ 3863 ] {d0381b1b-f566-431a-899e-7b3988aadb4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.397166 [ 3863 ] {4e892147-41e1-4164-97b7-743da0b341d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsInt256([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.398839 [ 3863 ] {4e892147-41e1-4164-97b7-743da0b341d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.416112 [ 3863 ] {d520dba2-8780-4a2f-a24c-5a3e9ded6e1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsInt32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.417483 [ 3863 ] {d520dba2-8780-4a2f-a24c-5a3e9ded6e1f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.435638 [ 3863 ] {500bb2f5-c948-4456-9ee2-e5b80cef3ffc} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsInt64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.437179 [ 3863 ] {500bb2f5-c948-4456-9ee2-e5b80cef3ffc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.455690 [ 3863 ] {998bde09-12c4-4df3-ba82-0988bfd268a2} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsInt8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.458209 [ 3863 ] {998bde09-12c4-4df3-ba82-0988bfd268a2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.475006 [ 3863 ] {8754ee56-c326-49fd-97c9-8baae12fa893} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.476465 [ 3863 ] {8754ee56-c326-49fd-97c9-8baae12fa893} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.583889 [ 3863 ] {205ac812-8dd1-4c07-bc5a-7a99d82ef507} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsUInt128([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.585272 [ 3863 ] {205ac812-8dd1-4c07-bc5a-7a99d82ef507} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.601428 [ 3863 ] {d1886562-e377-49c6-bc74-e4b7af71422a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsUInt16([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.602631 [ 3863 ] {d1886562-e377-49c6-bc74-e4b7af71422a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.673047 [ 3863 ] {41e7c35e-ab73-4d91-a47f-1a2cde524e3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsUInt256([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.674638 [ 3863 ] {41e7c35e-ab73-4d91-a47f-1a2cde524e3e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.692302 [ 3863 ] {ebf52a29-602e-4a84-8913-91baa418deea} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsUInt32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.693885 [ 3863 ] {ebf52a29-602e-4a84-8913-91baa418deea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.712423 [ 3863 ] {1dc37a41-78ea-490a-9c20-09022985640f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsUInt64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.713927 [ 3863 ] {1dc37a41-78ea-490a-9c20-09022985640f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.730343 [ 3863 ] {d68e76c1-9e23-4f59-ba76-86c594974a1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsUInt8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.731510 [ 3863 ] {d68e76c1-9e23-4f59-ba76-86c594974a1a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.749285 [ 3863 ] {7e9b9a37-e269-4490-b892-a2de779699dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reinterpretAsUUID([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.750675 [ 3863 ] {7e9b9a37-e269-4490-b892-a2de779699dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 3, should be 1: In scope SELECT reinterpretAsUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.767675 [ 3863 ] {19b1c85e-f7b7-440a-9e5a-c66c493cee77} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT repeat([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.768849 [ 3863 ] {19b1c85e-f7b7-440a-9e5a-c66c493cee77} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 3, should be 2: In scope SELECT repeat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.783988 [ 3863 ] {58e6ab85-09a9-4800-a8c6-3cb9654c3ab9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replace([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT replace([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.785165 [ 3863 ] {58e6ab85-09a9-4800-a8c6-3cb9654c3ab9} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replace([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:11.801004 [ 3863 ] {377a6525-41ca-45c6-a73f-2ceea0565c07} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT replaceAll([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.802198 [ 3863 ] {377a6525-41ca-45c6-a73f-2ceea0565c07} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:11.817895 [ 3863 ] {7e1f6d91-cbd1-43da-99d2-054b45dd440b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceOne'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceOne([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT replaceOne([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.819090 [ 3863 ] {7e1f6d91-cbd1-43da-99d2-054b45dd440b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceOne'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceOne([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:11.835562 [ 3863 ] {85101766-0a4b-4941-9238-4425666830ca} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceRegexpAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT replaceRegexpAll([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.836749 [ 3863 ] {85101766-0a4b-4941-9238-4425666830ca} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpAll'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceRegexpAll([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:11.851849 [ 3863 ] {8fb99953-f787-41b9-a66b-9641611f26ea} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpOne'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceRegexpOne([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT replaceRegexpOne([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.853105 [ 3863 ] {8fb99953-f787-41b9-a66b-9641611f26ea} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'replaceRegexpOne'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT replaceRegexpOne([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:11.899144 [ 3863 ] {1e4bde45-73ac-4cfb-8ec9-11fa4f1bd067} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of aggregate function retention, must be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT retention([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.900302 [ 3863 ] {1e4bde45-73ac-4cfb-8ec9-11fa4f1bd067} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of aggregate function retention, must be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:11.916340 [ 3863 ] {7fcc0be9-5bd9-425f-8a1d-1aa0f5476c06} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reverse([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.917528 [ 3863 ] {7fcc0be9-5bd9-425f-8a1d-1aa0f5476c06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 3, should be 1: In scope SELECT reverse([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.932821 [ 3863 ] {c36d382f-1884-4084-ad37-09f39f13959f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT reverseUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.934098 [ 3863 ] {c36d382f-1884-4084-ad37-09f39f13959f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 3, should be 1: In scope SELECT reverseUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.949227 [ 3863 ] {ba0db900-d895-4c2e-9d12-79cd859369f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT revision([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.950445 [ 3863 ] {ba0db900-d895-4c2e-9d12-79cd859369f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 3, should be 0: In scope SELECT revision([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.966250 [ 3863 ] {44fae82d-db5f-4cec-b2d0-7055fc75b9c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT right([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.967461 [ 3863 ] {44fae82d-db5f-4cec-b2d0-7055fc75b9c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 3, should be 2: In scope SELECT right([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:11.983684 [ 3863 ] {e9f33794-b705-4e19-823f-b6d6d783f8de} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPad, should be string: In scope SELECT rightPad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT rightPad([NULL], [NULL], [NULL]);) 2025.03.31 19:01:11.986728 [ 3863 ] {e9f33794-b705-4e19-823f-b6d6d783f8de} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPad, should be string: In scope SELECT rightPad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:12.002821 [ 3863 ] {9a655f97-17dc-45e0-bad6-3dac45d6f9da} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPadUTF8, should be string: In scope SELECT rightPadUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT rightPadUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.004024 [ 3863 ] {9a655f97-17dc-45e0-bad6-3dac45d6f9da} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPadUTF8, should be string: In scope SELECT rightPadUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:12.021591 [ 3863 ] {09a2718b-75d4-43c2-8636-7488049ae0df} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT rightUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.065803 [ 3863 ] {09a2718b-75d4-43c2-8636-7488049ae0df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 3, should be 2: In scope SELECT rightUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.084416 [ 3863 ] {15756f08-cfa4-4443-9593-220e26c27d7c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT round([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT round([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.086011 [ 3863 ] {15756f08-cfa4-4443-9593-220e26c27d7c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT round([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.103932 [ 3863 ] {b1ebc545-1cc1-442a-b369-3a7410a216cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT roundAge([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.105454 [ 3863 ] {b1ebc545-1cc1-442a-b369-3a7410a216cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 3, should be 1: In scope SELECT roundAge([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.122634 [ 3863 ] {6ceb3ba0-49d2-4750-85b0-0a531ad8f134} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT roundBankers([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT roundBankers([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.124141 [ 3863 ] {6ceb3ba0-49d2-4750-85b0-0a531ad8f134} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT roundBankers([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.140981 [ 3830 ] {7285c2b8-6427-459d-a699-5510cdd00544} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'YYYYMMDDhhmmssToDateTime'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8035 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:12.141456 [ 3863 ] {38063623-6823-4075-beba-50acf482e658} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT roundDown([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.141949 [ 3830 ] {7285c2b8-6427-459d-a699-5510cdd00544} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'YYYYMMDDhhmmssToDateTime'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8035 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:12.142658 [ 3863 ] {38063623-6823-4075-beba-50acf482e658} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 3, should be 2: In scope SELECT roundDown([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.208814 [ 3863 ] {74cd69a7-bee5-44c5-9119-4d975cdb4f80} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT roundDuration([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.210354 [ 3863 ] {74cd69a7-bee5-44c5-9119-4d975cdb4f80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 3, should be 1: In scope SELECT roundDuration([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.264077 [ 3863 ] {04e4631c-fa2f-469a-9439-043aee214ad3} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT roundToExp2([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.265538 [ 3863 ] {04e4631c-fa2f-469a-9439-043aee214ad3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 3, should be 1: In scope SELECT roundToExp2([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.284329 [ 3863 ] {4384bf02-b803-43c5-b01f-c3daf6a2a9c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT rowNumberInAllBlocks([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.285931 [ 3863 ] {4384bf02-b803-43c5-b01f-c3daf6a2a9c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 3, should be 0: In scope SELECT rowNumberInAllBlocks([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.304575 [ 3863 ] {6d92d02c-1043-4737-97e0-baa948daf8d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT rowNumberInBlock([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.305811 [ 3863 ] {6d92d02c-1043-4737-97e0-baa948daf8d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 3, should be 0: In scope SELECT rowNumberInBlock([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.498438 [ 3863 ] {0ef52fb8-f054-46a5-bfed-6448f9802c67} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT row_number([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.500640 [ 3863 ] {0ef52fb8-f054-46a5-bfed-6448f9802c67} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.03.31 19:01:12.521342 [ 3863 ] {57beaf7f-1190-4dbc-b0b9-99aa1879ffdf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPad, should be string: In scope SELECT rpad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT rpad([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.547836 [ 3863 ] {57beaf7f-1190-4dbc-b0b9-99aa1879ffdf} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of the first argument of function rightPad, should be string: In scope SELECT rpad([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:12.587578 [ 3863 ] {ad94437a-05ca-472a-9ebf-eda0a7f06d04} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT runningAccumulate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.589018 [ 3863 ] {ad94437a-05ca-472a-9ebf-eda0a7f06d04} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.03.31 19:01:12.607178 [ 3863 ] {af2447a8-1903-4b32-bf8b-f5ff78d56b01} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT runningConcurrency([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.608437 [ 3863 ] {af2447a8-1903-4b32-bf8b-f5ff78d56b01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 3, should be 2: In scope SELECT runningConcurrency([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.623669 [ 3863 ] {3c19467d-1fd8-4462-b0dd-1c3266169265} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT runningDifference([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.624903 [ 3863 ] {3c19467d-1fd8-4462-b0dd-1c3266169265} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.03.31 19:01:12.645681 [ 3863 ] {816bebf4-86c8-4919-963e-d8fbe7cbfd0f} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT runningDifferenceStartingWithFirstValue([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.646901 [ 3863 ] {816bebf4-86c8-4919-963e-d8fbe7cbfd0f} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.03.31 19:01:12.663137 [ 3863 ] {8e864ee0-e8be-49a2-9fe8-ec850d16637b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT s2CapContains([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.664106 [ 3863 ] {8e864ee0-e8be-49a2-9fe8-ec850d16637b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function s2CapContains. Must be UInt64: In scope SELECT s2CapContains([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:12.676783 [ 3863 ] {a7ef3a09-1952-41c8-bd63-431f230d0a2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT s2CapUnion([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.677673 [ 3863 ] {a7ef3a09-1952-41c8-bd63-431f230d0a2f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 3, should be 4: In scope SELECT s2CapUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.690201 [ 3863 ] {ee5b3b70-775b-4e89-8d98-0aa3fee380df} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT s2CellsIntersect([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.691293 [ 3863 ] {ee5b3b70-775b-4e89-8d98-0aa3fee380df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 3, should be 2: In scope SELECT s2CellsIntersect([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.758599 [ 3863 ] {cfd233a4-c8c5-46fa-93f8-a7232bfaf6ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT s2GetNeighbors([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.760240 [ 3863 ] {cfd233a4-c8c5-46fa-93f8-a7232bfaf6ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 3, should be 1: In scope SELECT s2GetNeighbors([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.776843 [ 3863 ] {f6abcc22-6e48-4e16-a2c4-6d2ba6b8af49} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of function s2RectAdd. Must be UInt64: In scope SELECT s2RectAdd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT s2RectAdd([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.778542 [ 3863 ] {f6abcc22-6e48-4e16-a2c4-6d2ba6b8af49} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of function s2RectAdd. Must be UInt64: In scope SELECT s2RectAdd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:12.824339 [ 3863 ] {588d676f-27e4-40f7-b1c6-6b796255bbf0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of function s2RectContains. Must be UInt64: In scope SELECT s2RectContains([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT s2RectContains([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.825639 [ 3863 ] {588d676f-27e4-40f7-b1c6-6b796255bbf0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 0 of function s2RectContains. Must be UInt64: In scope SELECT s2RectContains([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:12.843334 [ 3863 ] {d4776677-09cd-4b8e-b194-1d8788124b78} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT s2RectIntersection([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.844673 [ 3863 ] {d4776677-09cd-4b8e-b194-1d8788124b78} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 3, should be 4: In scope SELECT s2RectIntersection([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.860263 [ 3863 ] {a2a84911-8d20-45ad-b284-186e77803a02} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT s2RectUnion([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.861574 [ 3863 ] {a2a84911-8d20-45ad-b284-186e77803a02} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 3, should be 4: In scope SELECT s2RectUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.875998 [ 3863 ] {0bfa1f1e-923b-4464-bb72-2555abf3965a} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT s2ToGeo([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.877044 [ 3863 ] {0bfa1f1e-923b-4464-bb72-2555abf3965a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 3, should be 1: In scope SELECT s2ToGeo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.893516 [ 3863 ] {885339dd-fea1-4079-9c10-2b0cca2ca078} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT scalarProduct([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.894825 [ 3863 ] {885339dd-fea1-4079-9c10-2b0cca2ca078} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 3, should be 2: In scope SELECT scalarProduct([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.912319 [ 3863 ] {97aad7ba-25f2-4ba4-a615-20d736e0352b} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sequenceCount([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.913869 [ 3863 ] {97aad7ba-25f2-4ba4-a615-20d736e0352b} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.931672 [ 3863 ] {626ba119-f482-4d18-9219-e535720a7ae7} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sequenceMatch([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.933102 [ 3863 ] {626ba119-f482-4d18-9219-e535720a7ae7} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:12.952127 [ 3863 ] {2ac2484f-f2f0-4fd8-8114-63de699e2e4a} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sequenceNextNode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:12.953599 [ 3863 ] {2ac2484f-f2f0-4fd8-8114-63de699e2e4a} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.03.31 19:01:13.014725 [ 3863 ] {6957182d-b099-4241-b0e6-b30f59c0400b} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT seriesDecomposeSTL([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.016227 [ 3863 ] {6957182d-b099-4241-b0e6-b30f59c0400b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 3, should be 2: In scope SELECT seriesDecomposeSTL([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.033671 [ 3863 ] {22c687bc-3f34-4c88-88f5-6a890b3a1d63} executeQuery: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 3.: In scope SELECT seriesOutliersDetectTukey([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT seriesOutliersDetectTukey([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.035273 [ 3863 ] {22c687bc-3f34-4c88-88f5-6a890b3a1d63} TCPHandler: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 3.: In scope SELECT seriesOutliersDetectTukey([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.053370 [ 3863 ] {7e6350f5-794a-4b8e-90a7-741185664689} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT seriesPeriodDetectFFT([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.055151 [ 3863 ] {7e6350f5-794a-4b8e-90a7-741185664689} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 3, should be 1: In scope SELECT seriesPeriodDetectFFT([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.073249 [ 3863 ] {74ce5cea-1924-466a-bb35-cd68cb978433} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT serverTimeZone([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.149382 [ 3863 ] {74ce5cea-1924-466a-bb35-cd68cb978433} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.164579 [ 3863 ] {6498c2ff-4a74-4ce2-b264-a0c7fb318464} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT serverTimezone([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.165903 [ 3863 ] {6498c2ff-4a74-4ce2-b264-a0c7fb318464} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 3, should be 0: In scope SELECT serverTimezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.182141 [ 3863 ] {ede7de24-1786-44be-b729-5dc0b1014e6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT serverUUID([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.183582 [ 3863 ] {ede7de24-1786-44be-b729-5dc0b1014e6c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 3, should be 0: In scope SELECT serverUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.200918 [ 3863 ] {e461bf91-add6-4a8b-9d9c-978b7b10d38c} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT shardCount([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.202362 [ 3863 ] {e461bf91-add6-4a8b-9d9c-978b7b10d38c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 3, should be 0: In scope SELECT shardCount([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.220858 [ 3863 ] {16d9f450-f79d-44e0-bf16-a3ad4262d488} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT shardNum([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.222667 [ 3863 ] {16d9f450-f79d-44e0-bf16-a3ad4262d488} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 3, should be 0: In scope SELECT shardNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.242369 [ 3863 ] {069e3438-d402-49ae-8ab7-58c5d4643d35} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT showCertificate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.244003 [ 3863 ] {069e3438-d402-49ae-8ab7-58c5d4643d35} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 3, should be 0: In scope SELECT showCertificate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.262574 [ 3863 ] {0f3155c9-7dfa-4809-a847-f9ccf9214a76} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sigmoid([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.264231 [ 3863 ] {0f3155c9-7dfa-4809-a847-f9ccf9214a76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 3, should be 1: In scope SELECT sigmoid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.283955 [ 3863 ] {076e1019-687b-4c46-a194-c0e956d96667} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sign([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.291595 [ 3863 ] {076e1019-687b-4c46-a194-c0e956d96667} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 3, should be 1: In scope SELECT sign([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.311745 [ 3863 ] {5d8273dd-baed-43dd-a181-96ee23bc5df4} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT simpleJSONExtractBool([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.313375 [ 3863 ] {5d8273dd-baed-43dd-a181-96ee23bc5df4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.332006 [ 3863 ] {73d25222-1c8d-4314-8d12-0688df953d5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT simpleJSONExtractFloat([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.333886 [ 3863 ] {73d25222-1c8d-4314-8d12-0688df953d5f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractFloat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.351398 [ 3863 ] {ee12cc8c-f701-48c2-aff6-3dead9afc92a} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT simpleJSONExtractInt([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.352944 [ 3863 ] {ee12cc8c-f701-48c2-aff6-3dead9afc92a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.371624 [ 3863 ] {e11d84ee-1c3d-485c-ad15-fcadea72651c} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT simpleJSONExtractRaw([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.373159 [ 3863 ] {e11d84ee-1c3d-485c-ad15-fcadea72651c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractRaw([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.389680 [ 3863 ] {a6c71fcc-6fda-49b4-a78b-db371a21a0dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT simpleJSONExtractString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.391082 [ 3863 ] {a6c71fcc-6fda-49b4-a78b-db371a21a0dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.443948 [ 3863 ] {503793c9-5daa-43d1-9b6a-dcd84f3bd49c} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT simpleJSONExtractUInt([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.445331 [ 3863 ] {503793c9-5daa-43d1-9b6a-dcd84f3bd49c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT simpleJSONExtractUInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.460192 [ 3863 ] {e246cff0-2cf1-4cf6-87a6-b94162e95ce7} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT simpleJSONHas([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.461442 [ 3863 ] {e246cff0-2cf1-4cf6-87a6-b94162e95ce7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT simpleJSONHas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.476898 [ 3863 ] {04e9292c-37c4-46da-b41f-8fea2c78c6c7} executeQuery: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT simpleLinearRegression([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.478111 [ 3863 ] {04e9292c-37c4-46da-b41f-8fea2c78c6c7} TCPHandler: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.510123 [ 3863 ] {cac791a6-0e67-4d9d-9ba4-5f55483a2fcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sin([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.511400 [ 3863 ] {cac791a6-0e67-4d9d-9ba4-5f55483a2fcd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 3, should be 1: In scope SELECT sin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.526724 [ 3863 ] {c8b2803c-d56d-4fae-8956-75f5eb5bd225} executeQuery: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT singleValueOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.527747 [ 3863 ] {c8b2803c-d56d-4fae-8956-75f5eb5bd225} TCPHandler: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.629006 [ 3863 ] {f6cf847a-2409-4c52-9f9d-1a648ea4cc82} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sinh([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.630887 [ 3863 ] {f6cf847a-2409-4c52-9f9d-1a648ea4cc82} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 3, should be 1: In scope SELECT sinh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.650167 [ 3863 ] {1d0e616a-c276-4fc4-954f-2cec2007e476} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT sipHash128([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sipHash128([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.651645 [ 3863 ] {1d0e616a-c276-4fc4-954f-2cec2007e476} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT sipHash128([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:13.670517 [ 3863 ] {8cba9a37-e2c9-4af0-9872-c94e61cd6c4a} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sipHash128Keyed([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.671908 [ 3863 ] {8cba9a37-e2c9-4af0-9872-c94e61cd6c4a} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.03.31 19:01:13.751153 [ 3863 ] {407cf6be-8049-4ee2-acf2-168a4b40f810} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT sipHash128Reference([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sipHash128Reference([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.752927 [ 3863 ] {407cf6be-8049-4ee2-acf2-168a4b40f810} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT sipHash128Reference([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:13.771952 [ 3863 ] {08c04d7d-cc0a-453f-8fb0-9d2bc9bc3dfa} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sipHash128ReferenceKeyed([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.773543 [ 3863 ] {08c04d7d-cc0a-453f-8fb0-9d2bc9bc3dfa} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.03.31 19:01:13.808908 [ 3863 ] {f0304e26-e3d0-4431-b712-ef4b9cad8243} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT sipHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sipHash64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.810618 [ 3863 ] {f0304e26-e3d0-4431-b712-ef4b9cad8243} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT sipHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:13.829325 [ 3863 ] {1e24de94-826c-44a5-a796-b444e9442f37} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sipHash64Keyed([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.830956 [ 3863 ] {1e24de94-826c-44a5-a796-b444e9442f37} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed([NULL], [NULL], [NULL]). (BAD_ARGUMENTS) 2025.03.31 19:01:13.849158 [ 3863 ] {b2575e17-5d94-4b80-9a9b-05e7dd3b026f} executeQuery: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT skewPop([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.850755 [ 3863 ] {b2575e17-5d94-4b80-9a9b-05e7dd3b026f} TCPHandler: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.868360 [ 3863 ] {63657ca6-bead-496c-8abf-9b83a6fbe2f9} executeQuery: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT skewSamp([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.869605 [ 3863 ] {63657ca6-bead-496c-8abf-9b83a6fbe2f9} TCPHandler: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.892281 [ 3830 ] {3ea138c5-c77e-40e0-b8b2-c728b40c36d5} executeQuery: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'invalid tz'). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'invalid tz');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe1c87 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd2f16 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000003236d99a 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000003236ce9e 8. std::shared_ptr std::allocate_shared[abi:v15007], String&, void>(std::allocator const&, String&) @ 0x000000000dc7c703 9. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa3ae9 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 2025.03.31 19:01:13.892306 [ 3863 ] {40bc888f-4695-49fb-9393-6e73a05ae0d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sleep([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.893069 [ 3830 ] {3ea138c5-c77e-40e0-b8b2-c728b40c36d5} TCPHandler: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'invalid tz'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe1c87 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd2f16 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000003236d99a 7. ./build_docker/./src/DataTypes/DataTypeDateTime.cpp:12: DB::DataTypeDateTime::DataTypeDateTime(String const&) @ 0x000000003236ce9e 8. std::shared_ptr std::allocate_shared[abi:v15007], String&, void>(std::allocator const&, String&) @ 0x000000000dc7c703 9. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa3ae9 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 2025.03.31 19:01:13.893440 [ 3863 ] {40bc888f-4695-49fb-9393-6e73a05ae0d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 3, should be 1: In scope SELECT sleep([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.905219 [ 3830 ] {90945fb7-6ca6-4148-8995-5baa5e29e30a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'Europe/Berlin', 'bad'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'Europe/Berlin', 'bad');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x00000000083fea57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8cc9 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:01:13.906089 [ 3830 ] {90945fb7-6ca6-4148-8995-5baa5e29e30a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(20230911134254, 'Europe/Berlin', 'bad'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x00000000083fea57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8cc9 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa38c7 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:01:13.907825 [ 3863 ] {df1c47e5-e1ad-439f-b4b2-e3d2011a19ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sleepEachRow([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.908952 [ 3863 ] {df1c47e5-e1ad-439f-b4b2-e3d2011a19ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 3, should be 1: In scope SELECT sleepEachRow([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.925687 [ 3863 ] {cf567df2-6983-4f55-862f-5b085ad0bf61} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Array(Nullable(Nothing)): In scope SELECT snowflakeIDToDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT snowflakeIDToDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.927172 [ 3863 ] {cf567df2-6983-4f55-862f-5b085ad0bf61} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Array(Nullable(Nothing)): In scope SELECT snowflakeIDToDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:13.945616 [ 3863 ] {bc3499c1-c6d9-40cc-be0b-bf8bb11e1da3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Array(Nullable(Nothing)): In scope SELECT snowflakeIDToDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT snowflakeIDToDateTime64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.947480 [ 3863 ] {bc3499c1-c6d9-40cc-be0b-bf8bb11e1da3} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Array(Nullable(Nothing)): In scope SELECT snowflakeIDToDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:13.963205 [ 3863 ] {e5650a6d-bfdf-4db4-8682-456c42c425f2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT snowflakeToDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.964803 [ 3863 ] {e5650a6d-bfdf-4db4-8682-456c42c425f2} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:13.982666 [ 3863 ] {8b46fac2-2d8b-421f-aa99-a2b02beb59b4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT snowflakeToDateTime64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:13.984160 [ 3863 ] {8b46fac2-2d8b-421f-aa99-a2b02beb59b4} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT snowflakeToDateTime64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.001180 [ 3863 ] {2e440ae7-2138-4d96-a112-56fe2caf2e59} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT soundex([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.003057 [ 3863 ] {2e440ae7-2138-4d96-a112-56fe2caf2e59} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 3, should be 1: In scope SELECT soundex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.021286 [ 3863 ] {192f9dca-e21e-49a9-b855-9966c63a4e96} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT space([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.022989 [ 3863 ] {192f9dca-e21e-49a9-b855-9966c63a4e96} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 3, should be 1: In scope SELECT space([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.040393 [ 3863 ] {22d130be-a6e4-4557-a812-905be340bc4c} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sparkBar([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.042029 [ 3863 ] {22d130be-a6e4-4557-a812-905be340bc4c} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.057021 [ 3863 ] {8422a7dd-4bfc-4df4-b891-b172473ae28b} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sparkbar([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.058333 [ 3863 ] {8422a7dd-4bfc-4df4-b891-b172473ae28b} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.088040 [ 6148 ] {3ea77b09-e5ed-499c-b6d1-54d2e3dd611b} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.join, because some tables depend on it: test_krdjlok0.s, test_krdjlok0.t (1028df92-0726-4b20-9013-d248623e36da), test_krdjlok0.dict2. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51240) (comment: 01160_table_dependencies.sh) (in query: rename table join to join1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000339c1448 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc1a2a 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbc095 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:14.090032 [ 6148 ] {3ea77b09-e5ed-499c-b6d1-54d2e3dd611b} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.join, because some tables depend on it: test_krdjlok0.s, test_krdjlok0.t (1028df92-0726-4b20-9013-d248623e36da), test_krdjlok0.dict2. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000339c1448 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc1a2a 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbc095 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:14.234283 [ 3863 ] {e1e10107-60df-459a-9755-567d7e87bd4a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByAlpha([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT splitByAlpha([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.235945 [ 3863 ] {e1e10107-60df-459a-9755-567d7e87bd4a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByAlpha([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.253264 [ 3863 ] {1cf7976c-b131-4415-8d15-3c028a4a80a2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByChar'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByChar([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT splitByChar([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.254701 [ 3863 ] {1cf7976c-b131-4415-8d15-3c028a4a80a2} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByChar'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByChar([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:14.270662 [ 3863 ] {55ad9b7e-51e4-48e4-a033-db1f79f201d9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByNonAlpha([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT splitByNonAlpha([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.271918 [ 3863 ] {55ad9b7e-51e4-48e4-a033-db1f79f201d9} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByNonAlpha([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.389270 [ 3863 ] {0e3dc5a3-d9a9-4553-86c3-b8f89cfdf8c3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByRegexp'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByRegexp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT splitByRegexp([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.390979 [ 3863 ] {0e3dc5a3-d9a9-4553-86c3-b8f89cfdf8c3} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByRegexp'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByRegexp([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:14.408269 [ 3863 ] {6693f4ac-ffc6-46ce-9617-cd5c3f7d6e14} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByString'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT splitByString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.409925 [ 3863 ] {6693f4ac-ffc6-46ce-9617-cd5c3f7d6e14} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByString'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT splitByString([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:14.427760 [ 3863 ] {4ca5bbb8-4c8c-4d25-99b5-d6ca99c2d7b4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByWhitespace([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT splitByWhitespace([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.429680 [ 3863 ] {4ca5bbb8-4c8c-4d25-99b5-d6ca99c2d7b4} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT splitByWhitespace([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.451195 [ 3863 ] {767e821b-a514-4275-97d9-c256538ecba5} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nullable(Nothing)).: In scope SELECT sqid([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sqid([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.452574 [ 3863 ] {767e821b-a514-4275-97d9-c256538ecba5} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nullable(Nothing)).: In scope SELECT sqid([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:14.473424 [ 3863 ] {fe9c318e-9d2c-4c2e-b6e5-99ac773dd1d5} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sqidDecode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.573690 [ 3863 ] {fe9c318e-9d2c-4c2e-b6e5-99ac773dd1d5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 3, should be 1: In scope SELECT sqidDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.702629 [ 3863 ] {88b214d9-92ee-4f77-8ef4-7a94854ed16b} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nullable(Nothing)).: In scope SELECT sqidEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sqidEncode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.704076 [ 3863 ] {88b214d9-92ee-4f77-8ef4-7a94854ed16b} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nullable(Nothing)).: In scope SELECT sqidEncode([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:14.773031 [ 3863 ] {83cf9d20-7b65-4385-ae47-e4edf55467ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sqrt([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.774665 [ 3863 ] {83cf9d20-7b65-4385-ae47-e4edf55467ab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 3, should be 1: In scope SELECT sqrt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.792769 [ 3863 ] {e900530d-8274-4e2a-8caa-a094adea9db0} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT startsWith([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.794186 [ 3863 ] {e900530d-8274-4e2a-8caa-a094adea9db0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 3, should be 2: In scope SELECT startsWith([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.810967 [ 3863 ] {e0d102cc-9359-46e6-81a5-ad717fdb9a47} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT startsWithUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.812527 [ 3863 ] {e0d102cc-9359-46e6-81a5-ad717fdb9a47} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 3, should be 2: In scope SELECT startsWithUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.829492 [ 3863 ] {529a748d-9e2e-4033-8849-68924b45ffd5} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT stddevPop([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.830947 [ 3863 ] {529a748d-9e2e-4033-8849-68924b45ffd5} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.845945 [ 3863 ] {b69632a2-9957-4701-9e5f-dad28d3f78fe} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT stddevPopStable([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.847215 [ 3863 ] {b69632a2-9957-4701-9e5f-dad28d3f78fe} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.861907 [ 3863 ] {e04908a1-28b9-49e8-888c-83e13b9973ff} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT stddevSamp([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.863062 [ 3863 ] {e04908a1-28b9-49e8-888c-83e13b9973ff} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.876975 [ 3863 ] {45c38222-e009-49fc-9ad9-9b04385dcc1e} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT stddevSampStable([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.878208 [ 3863 ] {45c38222-e009-49fc-9ad9-9b04385dcc1e} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.895741 [ 3863 ] {eb73f3f9-0dce-453b-ad75-03e205a4ea26} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT stem([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.897220 [ 3863 ] {eb73f3f9-0dce-453b-ad75-03e205a4ea26} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:01:14.912538 [ 3863 ] {a2d45521-fdaa-4ffe-a7cd-2196f86954e5} executeQuery: Code: 43. DB::Exception: Argument 0 of type Array(Nullable(Nothing)) must be numeric for aggregate function stochasticLinearRegression. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT stochasticLinearRegression([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.914086 [ 3863 ] {a2d45521-fdaa-4ffe-a7cd-2196f86954e5} TCPHandler: Code: 43. DB::Exception: Argument 0 of type Array(Nullable(Nothing)) must be numeric for aggregate function stochasticLinearRegression. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:14.929125 [ 3863 ] {70df2cc2-bb65-420d-b81d-8b7b7b404861} executeQuery: Code: 43. DB::Exception: Argument 0 of type Array(Nullable(Nothing)) must be numeric for aggregate function stochasticLogisticRegression. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT stochasticLogisticRegression([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.930555 [ 3863 ] {70df2cc2-bb65-420d-b81d-8b7b7b404861} TCPHandler: Code: 43. DB::Exception: Argument 0 of type Array(Nullable(Nothing)) must be numeric for aggregate function stochasticLogisticRegression. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:14.944779 [ 3863 ] {2db9442f-0d02-412d-b093-37198ce7b969} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT str_to_date([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT str_to_date([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.946092 [ 3863 ] {2db9442f-0d02-412d-b093-37198ce7b969} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT str_to_date([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:14.959958 [ 3863 ] {354e14bf-730f-4160-bea8-3b69b146e169} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT str_to_map([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT str_to_map([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.961284 [ 3863 ] {354e14bf-730f-4160-bea8-3b69b146e169} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument data_column. Must be String.: In scope SELECT str_to_map([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:14.975262 [ 3863 ] {52596429-9edd-4dc5-a744-6cbe67b86468} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT stringJaccardIndex([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.976425 [ 3863 ] {52596429-9edd-4dc5-a744-6cbe67b86468} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:14.990419 [ 3863 ] {1a29351e-f61e-483a-91bd-14276e513d8e} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT stringJaccardIndexUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:14.991738 [ 3863 ] {1a29351e-f61e-483a-91bd-14276e513d8e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 3, should be 2: In scope SELECT stringJaccardIndexUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.008459 [ 3863 ] {2733e8fe-35d9-4b1a-8546-2cc8b81f0ada} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT stringToH3([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.010088 [ 3863 ] {2733e8fe-35d9-4b1a-8546-2cc8b81f0ada} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 3, should be 1: In scope SELECT stringToH3([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.026270 [ 3863 ] {89b808f1-0751-4364-8582-ecb5126fa485} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT structureToCapnProtoSchema([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.027734 [ 3863 ] {89b808f1-0751-4364-8582-ecb5126fa485} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToCapnProtoSchema([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.042915 [ 3863 ] {bd0c68e3-9258-4474-a5fb-2e2db1e30e53} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT structureToProtobufSchema([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.044134 [ 3863 ] {bd0c68e3-9258-4474-a5fb-2e2db1e30e53} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 3, expected 1 or 2: In scope SELECT structureToProtobufSchema([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.058840 [ 3863 ] {112622ae-02d4-4036-a90c-3d35ef566b4f} executeQuery: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT studentTTest([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.060093 [ 3863 ] {112622ae-02d4-4036-a90c-3d35ef566b4f} TCPHandler: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.076784 [ 3863 ] {0452ca6f-c9b8-4c7e-b91a-3f7d9eda8c18} executeQuery: Code: 43. DB::Exception: First argument for function subBitmap must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT subBitmap([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subBitmap([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.078352 [ 3863 ] {0452ca6f-c9b8-4c7e-b91a-3f7d9eda8c18} TCPHandler: Code: 43. DB::Exception: First argument for function subBitmap must be a bitmap but it has type Array(Nullable(Nothing)).: In scope SELECT subBitmap([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.095694 [ 3863 ] {e1788aaf-337b-428d-8f20-c9a68aa6c080} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subDate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.097096 [ 3863 ] {e1788aaf-337b-428d-8f20-c9a68aa6c080} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 3, should be 2: In scope SELECT subDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.113675 [ 3863 ] {6c112401-d7e2-41c6-895c-03e326325a9a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT substr([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.115102 [ 3863 ] {6c112401-d7e2-41c6-895c-03e326325a9a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substr([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.143642 [ 3863 ] {4d18d446-0bda-4542-b6e8-7a27cdb1d8cf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substring([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT substring([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.144926 [ 3863 ] {4d18d446-0bda-4542-b6e8-7a27cdb1d8cf} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substring([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.160168 [ 3863 ] {293375bf-ec91-47bd-a4ca-236e34b407fb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndex, String expected: In scope SELECT substringIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT substringIndex([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.161322 [ 3863 ] {293375bf-ec91-47bd-a4ca-236e34b407fb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndex, String expected: In scope SELECT substringIndex([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.176574 [ 3863 ] {0a6af6cd-db8e-462e-9d4e-2cae4aa5b002} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndexUTF8, String expected: In scope SELECT substringIndexUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT substringIndexUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.178047 [ 3863 ] {0a6af6cd-db8e-462e-9d4e-2cae4aa5b002} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringIndexUTF8, String expected: In scope SELECT substringIndexUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.194440 [ 3863 ] {50e8ec5d-f505-45ab-aec6-a93f631bf714} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringUTF8, expected String: In scope SELECT substringUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT substringUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.195874 [ 3863 ] {50e8ec5d-f505-45ab-aec6-a93f631bf714} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function substringUTF8, expected String: In scope SELECT substringUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.211246 [ 3863 ] {380bc253-ee15-468b-8b95-b2cb12b0474f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope SELECT subtractDays([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractDays([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.212516 [ 3863 ] {380bc253-ee15-468b-8b95-b2cb12b0474f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope SELECT subtractDays([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.228657 [ 3863 ] {36e29eda-9147-4255-8128-e696ff429808} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope SELECT subtractHours([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractHours([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.230078 [ 3863 ] {36e29eda-9147-4255-8128-e696ff429808} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope SELECT subtractHours([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.246876 [ 3863 ] {09cb5423-24ba-4843-b3e2-4f687f5832d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractInterval([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.248116 [ 3863 ] {09cb5423-24ba-4843-b3e2-4f687f5832d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 3, should be 2: In scope SELECT subtractInterval([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.355779 [ 3863 ] {b15b649c-6196-490c-92d4-33ade4947672} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMicroseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMicroseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractMicroseconds([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.357171 [ 3863 ] {b15b649c-6196-490c-92d4-33ade4947672} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMicroseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMicroseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.374456 [ 3863 ] {8a055a06-1e69-43f4-a414-cbad623780b1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMilliseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMilliseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractMilliseconds([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.375897 [ 3863 ] {8a055a06-1e69-43f4-a414-cbad623780b1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMilliseconds. Must be a DateTime/DateTime64: In scope SELECT subtractMilliseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.444861 [ 3863 ] {264d33a1-bd34-47c6-ac98-4a4adf618d26} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope SELECT subtractMinutes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractMinutes([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.446366 [ 3863 ] {264d33a1-bd34-47c6-ac98-4a4adf618d26} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope SELECT subtractMinutes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.464018 [ 3863 ] {e388b893-adf5-4bf4-8b27-91228dc8c304} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope SELECT subtractMonths([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractMonths([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.465201 [ 3863 ] {e388b893-adf5-4bf4-8b27-91228dc8c304} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope SELECT subtractMonths([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.481304 [ 3863 ] {64b5dc37-962f-44ac-a8f5-17928491645e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractNanoseconds. Must be a DateTime/DateTime64: In scope SELECT subtractNanoseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractNanoseconds([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.482642 [ 3863 ] {64b5dc37-962f-44ac-a8f5-17928491645e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractNanoseconds. Must be a DateTime/DateTime64: In scope SELECT subtractNanoseconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.499298 [ 3863 ] {939ef0e9-a01b-4048-afd6-ff587483765b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope SELECT subtractQuarters([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractQuarters([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.500487 [ 3863 ] {939ef0e9-a01b-4048-afd6-ff587483765b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope SELECT subtractQuarters([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.516627 [ 3863 ] {db6ea2f0-7f7e-47d5-a840-3b5353d885ba} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope SELECT subtractSeconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractSeconds([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.517906 [ 3863 ] {db6ea2f0-7f7e-47d5-a840-3b5353d885ba} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope SELECT subtractSeconds([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.533414 [ 3863 ] {c5e6ddcd-5561-4029-b249-f733f037dd8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractTupleOfIntervals([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.534666 [ 3863 ] {c5e6ddcd-5561-4029-b249-f733f037dd8d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 3, should be 2: In scope SELECT subtractTupleOfIntervals([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.550375 [ 3863 ] {ad517755-607b-4700-9448-296216692a74} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope SELECT subtractWeeks([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractWeeks([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.551666 [ 3863 ] {ad517755-607b-4700-9448-296216692a74} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope SELECT subtractWeeks([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.567465 [ 3863 ] {e1a1db76-1beb-473d-9125-65e37364f646} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope SELECT subtractYears([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT subtractYears([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.568664 [ 3863 ] {e1a1db76-1beb-473d-9125-65e37364f646} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope SELECT subtractYears([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.583949 [ 3863 ] {d72bb73d-73a8-4c54-95e6-36636df476da} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sum([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.585214 [ 3863 ] {d72bb73d-73a8-4c54-95e6-36636df476da} TCPHandler: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.601586 [ 3863 ] {bd67b898-b9f7-4487-b465-73f50b0e01f6} executeQuery: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sumCount([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.602913 [ 3863 ] {bd67b898-b9f7-4487-b465-73f50b0e01f6} TCPHandler: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.617558 [ 3863 ] {45fdf767-2c11-4e6d-94d6-a548d5f5cbea} executeQuery: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sumKahan([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.626709 [ 3863 ] {45fdf767-2c11-4e6d-94d6-a548d5f5cbea} TCPHandler: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.642333 [ 3863 ] {ee7aebb6-d00a-4f34-a7da-65a8b8f496ee} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sumMapFiltered([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.643630 [ 3863 ] {ee7aebb6-d00a-4f34-a7da-65a8b8f496ee} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.661230 [ 3863 ] {1c92bd5f-bb6f-45e4-aa58-84a784590081} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sumMapFilteredWithOverflow([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.662736 [ 3863 ] {1c92bd5f-bb6f-45e4-aa58-84a784590081} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.679121 [ 3863 ] {38403fdf-ac45-43fc-ba3e-8e42ce437397} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sumMapWithOverflow([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.680541 [ 3863 ] {38403fdf-ac45-43fc-ba3e-8e42ce437397} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.716649 [ 6148 ] {778614c7-e1e5-4139-b893-7f9abd99e722} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.join (c30b82ea-d4c6-40a4-8bb7-8a8a8f60cd70), because some tables depend on it: test_krdjlok0.s, test_krdjlok0.t (1028df92-0726-4b20-9013-d248623e36da), test_krdjlok0.dict2. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51272) (comment: 01160_table_dependencies.sh) (in query: drop table join), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c41f9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034929042 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:15.718316 [ 6148 ] {778614c7-e1e5-4139-b893-7f9abd99e722} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.join (c30b82ea-d4c6-40a4-8bb7-8a8a8f60cd70), because some tables depend on it: test_krdjlok0.s, test_krdjlok0.t (1028df92-0726-4b20-9013-d248623e36da), test_krdjlok0.dict2. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c41f9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034929042 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:15.790310 [ 3863 ] {f57507c6-7557-48ab-a8c4-d0dcf68903a1} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sumMappedArrays([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.791866 [ 3863 ] {f57507c6-7557-48ab-a8c4-d0dcf68903a1} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:15.810162 [ 3863 ] {f8423cbe-08de-4051-ae5b-ad7d31c938ef} executeQuery: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT sumWithOverflow([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.811866 [ 3863 ] {f8423cbe-08de-4051-ae5b-ad7d31c938ef} TCPHandler: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.853666 [ 3863 ] {83e84f3e-47d4-44d8-8cbe-897937012e62} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT svg([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.855327 [ 3863 ] {83e84f3e-47d4-44d8-8cbe-897937012e62} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.872206 [ 3863 ] {6db3ec26-6bb5-4a86-b150-fc4dc2320f6b} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT synonyms([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.873619 [ 3863 ] {6db3ec26-6bb5-4a86-b150-fc4dc2320f6b} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:01:15.894837 [ 3863 ] {35945289-d86a-4b58-8173-dd733e00a3ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tan([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.896413 [ 3863 ] {35945289-d86a-4b58-8173-dd733e00a3ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 3, should be 1: In scope SELECT tan([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.916059 [ 3863 ] {6b0f281a-b838-4f9a-9168-81ab6c421199} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tanh([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.917574 [ 3863 ] {6b0f281a-b838-4f9a-9168-81ab6c421199} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 3, should be 1: In scope SELECT tanh([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.934392 [ 3863 ] {a40359eb-9692-40a9-b233-77cdf34fff5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tcpPort([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.935799 [ 3863 ] {a40359eb-9692-40a9-b233-77cdf34fff5f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 3, should be 0: In scope SELECT tcpPort([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.953036 [ 3863 ] {bf0efe5e-2f52-4beb-a638-f9f3f52658c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT test_function([NULL], [NULL], [NULL]);) 2025.03.31 19:01:15.954833 [ 3863 ] {bf0efe5e-2f52-4beb-a638-f9f3f52658c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 3, should be 2: In scope SELECT test_function([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:15.969401 [ 3863 ] {9c0b9ae2-94ce-4725-95cb-4ce8e3ea8dd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tgamma([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.051069 [ 3863 ] {9c0b9ae2-94ce-4725-95cb-4ce8e3ea8dd3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 3, should be 1: In scope SELECT tgamma([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.067598 [ 3863 ] {2235492f-954c-4388-a0e5-c58f25b95cfc} executeQuery: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT theilsU([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.068904 [ 3863 ] {2235492f-954c-4388-a0e5-c58f25b95cfc} TCPHandler: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.086301 [ 3863 ] {c46e9458-1f59-4a6c-beb2-06d20573832f} executeQuery: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT throwIf([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.087579 [ 3863 ] {c46e9458-1f59-4a6c-beb2-06d20573832f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.102961 [ 3863 ] {9500cd51-3d13-4e94-a599-0f2b7a9db2c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tid([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.104211 [ 3863 ] {9500cd51-3d13-4e94-a599-0f2b7a9db2c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 3, should be 0: In scope SELECT tid([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.119093 [ 3863 ] {9bb73a12-a2f0-4a08-9d67-e2da1f7b4f6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timeDiff([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.120338 [ 3863 ] {9bb73a12-a2f0-4a08-9d67-e2da1f7b4f6d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 3, should be 2: In scope SELECT timeDiff([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.135971 [ 3863 ] {42b73b2e-b2bd-413b-b50f-00d36d6bb949} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 3, should be 1 or 2: In scope SELECT timeSlot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timeSlot([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.137241 [ 3863 ] {42b73b2e-b2bd-413b-b50f-00d36d6bb949} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 3, should be 1 or 2: In scope SELECT timeSlot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.171885 [ 3863 ] {03013f70-5ccf-43b8-827e-13ef690885ce} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function timeSlots. Must be DateTime or DateTime64.: In scope SELECT timeSlots([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timeSlots([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.173122 [ 3863 ] {03013f70-5ccf-43b8-827e-13ef690885ce} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function timeSlots. Must be DateTime or DateTime64.: In scope SELECT timeSlots([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:16.189534 [ 3863 ] {9d3a20c1-d79a-4183-b6fc-674f3e7053f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timeZone([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.190947 [ 3863 ] {9d3a20c1-d79a-4183-b6fc-674f3e7053f7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.207235 [ 3863 ] {a30fb5be-8ea0-44aa-ae9c-bf2af77eafcd} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timeZoneOf([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.208456 [ 3863 ] {a30fb5be-8ea0-44aa-ae9c-bf2af77eafcd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timeZoneOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.224688 [ 3863 ] {73578e21-2706-487a-a491-4e3b7b6f2593} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timeZoneOffset([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timeZoneOffset([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.226003 [ 3863 ] {73578e21-2706-487a-a491-4e3b7b6f2593} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timeZoneOffset([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.287213 [ 3863 ] {fa05d80c-56d8-47a0-817c-0f149373fda0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timestamp([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.288450 [ 3863 ] {fa05d80c-56d8-47a0-817c-0f149373fda0} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.304592 [ 3863 ] {48175fec-49c6-48f0-a622-570e0578041f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timestampDiff([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.361132 [ 3830 ] {ba201e69-9045-4180-b8b7-6fe2838239f3} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(nan). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(NaN);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa2e68 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:16.362135 [ 3830 ] {ba201e69-9045-4180-b8b7-6fe2838239f3} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa2e68 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:16.372669 [ 3830 ] {8afc92f9-227a-412f-83d5-fd8256963d6d} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(inf). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa2e68 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:16.373322 [ 3830 ] {8afc92f9-227a-412f-83d5-fd8256963d6d} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa2e68 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:16.382312 [ 3830 ] {6dbd9f63-74fe-4e5c-ba0f-058bc32fc2b5} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(-inf). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime(-Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa2e68 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:16.382908 [ 3830 ] {6dbd9f63-74fe-4e5c-ba0f-058bc32fc2b5} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime(-inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa2e68 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:16.402520 [ 3863 ] {48175fec-49c6-48f0-a622-570e0578041f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:16.419515 [ 3863 ] {0ebefae8-4b97-4cb8-81d4-ab2d4a994b7d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timestamp_diff([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.420900 [ 3863 ] {0ebefae8-4b97-4cb8-81d4-ab2d4a994b7d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'unit' to function 'dateDiff'. Expected: String, got: Array(Nullable(Nothing)): In scope SELECT dateDiff([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:16.435525 [ 3863 ] {ad3a99c0-600a-4c47-844b-3cc9d0f6014e} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timezone([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.436899 [ 3863 ] {ad3a99c0-600a-4c47-844b-3cc9d0f6014e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 3, should be 0: In scope SELECT timezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.452791 [ 3863 ] {f0e9743f-353a-45e4-bdd8-966a3dfe98fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timezoneOf([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.454384 [ 3863 ] {f0e9743f-353a-45e4-bdd8-966a3dfe98fe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 3, should be 1: In scope SELECT timezoneOf([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.469144 [ 3863 ] {84505b51-44a0-4ece-aae2-ba795e65ec7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timezoneOffset([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT timezoneOffset([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.470583 [ 3863 ] {84505b51-44a0-4ece-aae2-ba795e65ec7c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 3, should be 1 or 2: In scope SELECT timezoneOffset([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.519323 [ 3863 ] {377e79d0-a4d2-4490-a91b-a58f871813d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toBool([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.520777 [ 3863 ] {377e79d0-a4d2-4490-a91b-a58f871813d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 3, should be 1: In scope SELECT toBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.536687 [ 3863 ] {699b6ecc-371f-4fca-ba32-1325dc22f494} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toColumnTypeName([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.538327 [ 3863 ] {699b6ecc-371f-4fca-ba32-1325dc22f494} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 3, should be 1: In scope SELECT toColumnTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.553402 [ 3863 ] {216f9072-2f75-4534-a015-c438694b6f28} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.554893 [ 3863 ] {216f9072-2f75-4534-a015-c438694b6f28} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.571026 [ 3863 ] {f6242296-289c-4d39-8076-75ec26bf59c2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDate32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.572217 [ 3863 ] {f6242296-289c-4d39-8076-75ec26bf59c2} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.587694 [ 3863 ] {74b8068b-7889-43d2-b012-29e40372de1d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDate32OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.588904 [ 3863 ] {74b8068b-7889-43d2-b012-29e40372de1d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDate32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.604419 [ 3863 ] {05776b7a-398e-4367-b7a8-abe493b4989c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDate32OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.605694 [ 3863 ] {05776b7a-398e-4367-b7a8-abe493b4989c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.698708 [ 3863 ] {c9be95fc-2bd8-4f9b-af54-1eb2649aef7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDate32OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.700042 [ 3863 ] {c9be95fc-2bd8-4f9b-af54-1eb2649aef7f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.714992 [ 3863 ] {45646c7c-305c-441e-bd09-908b1fdaa46f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateOrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.716381 [ 3863 ] {45646c7c-305c-441e-bd09-908b1fdaa46f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.779378 [ 3863 ] {842c1860-6c7d-4a3d-9b8f-2960a46df834} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.780664 [ 3863 ] {842c1860-6c7d-4a3d-9b8f-2960a46df834} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.794768 [ 3863 ] {25826091-0db8-46f4-84ee-62bf663f413d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.795853 [ 3863 ] {25826091-0db8-46f4-84ee-62bf663f413d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.809832 [ 3863 ] {671e1380-6f16-4d6e-ab7b-f9b0755bd684} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateTime([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.810902 [ 3863 ] {671e1380-6f16-4d6e-ab7b-f9b0755bd684} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:16.823868 [ 3863 ] {aaf89e25-8695-4aaa-a8c4-c8f6764224a4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateTime32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateTime32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.824839 [ 3863 ] {aaf89e25-8695-4aaa-a8c4-c8f6764224a4} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toDateTime32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.837980 [ 3863 ] {8250fa5d-a0b3-4c2c-8e6f-445b02bc78d2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateTime64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.838872 [ 3863 ] {8250fa5d-a0b3-4c2c-8e6f-445b02bc78d2} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:16.852461 [ 3863 ] {b089b0e6-9780-4feb-861f-cdb73f4b6ad4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateTime64OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.854028 [ 3863 ] {b089b0e6-9780-4feb-861f-cdb73f4b6ad4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:16.866731 [ 3863 ] {2341b822-3120-4882-b33b-9359e83f4b65} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateTime64OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.867899 [ 3863 ] {2341b822-3120-4882-b33b-9359e83f4b65} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrNull([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:16.882178 [ 3863 ] {cf18bec6-0fcf-4f9f-bca3-6448ec3e9701} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateTime64OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.883425 [ 3863 ] {cf18bec6-0fcf-4f9f-bca3-6448ec3e9701} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Array(Nullable(Nothing)): In scope SELECT toDateTime64OrZero([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:16.896988 [ 3863 ] {a5c99599-1e18-4ecb-8b84-7a99d25333c6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT toDateTimeOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateTimeOrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.897981 [ 3863 ] {a5c99599-1e18-4ecb-8b84-7a99d25333c6} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Array(Nullable(Nothing)): In scope SELECT toDateTimeOrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:16.909029 [ 3863 ] {60ca52eb-b7ef-420f-b6b1-79657d973a98} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateTimeOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.910136 [ 3863 ] {60ca52eb-b7ef-420f-b6b1-79657d973a98} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.921209 [ 3863 ] {349fb64b-a885-4bc2-b97e-191f811e89b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDateTimeOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.922133 [ 3863 ] {349fb64b-a885-4bc2-b97e-191f811e89b9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.932408 [ 3863 ] {85e6dc30-6e41-47a6-91e0-20278aaef1fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDayOfMonth([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.933277 [ 3863 ] {85e6dc30-6e41-47a6-91e0-20278aaef1fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:16.943319 [ 3863 ] {94c7296b-118d-401c-a6d6-08791689fc7e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDayOfWeek([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.944201 [ 3863 ] {94c7296b-118d-401c-a6d6-08791689fc7e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:16.955613 [ 3863 ] {aa2e4e5b-a901-4786-a735-d9f76a5039d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDayOfYear([NULL], [NULL], [NULL]);) 2025.03.31 19:01:16.956363 [ 3863 ] {aa2e4e5b-a901-4786-a735-d9f76a5039d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toDayOfYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.015604 [ 3863 ] {2ab91202-4235-4900-a4ce-ba3ddd152ed7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT toDaysSinceYearZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDaysSinceYearZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.016881 [ 3863 ] {2ab91202-4235-4900-a4ce-ba3ddd152ed7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 3, should be 1 or 2: In scope SELECT toDaysSinceYearZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.064194 [ 3863 ] {0fba9858-b733-41c0-b40b-8f24930aeb72} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal128([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.065507 [ 3863 ] {0fba9858-b733-41c0-b40b-8f24930aeb72} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.080010 [ 3863 ] {b7b34bda-7605-4fd6-86aa-517d0f6bb757} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal128OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal128OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.081858 [ 3863 ] {b7b34bda-7605-4fd6-86aa-517d0f6bb757} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal128OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:17.093097 [ 3863 ] {77960715-3f93-497b-8758-a76320b44a57} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal128OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.094287 [ 3863 ] {77960715-3f93-497b-8758-a76320b44a57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.105126 [ 3863 ] {0390a268-4980-4396-9eea-00cdb2534c19} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal128OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.106108 [ 3863 ] {0390a268-4980-4396-9eea-00cdb2534c19} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.116350 [ 3863 ] {246d5603-d7ab-45e6-8472-53b6907ac342} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal256([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.117230 [ 3863 ] {246d5603-d7ab-45e6-8472-53b6907ac342} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.127402 [ 3863 ] {3d77acab-05c9-41a8-acbf-e9aa86e93c5c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal256OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal256OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.128211 [ 3863 ] {3d77acab-05c9-41a8-acbf-e9aa86e93c5c} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal256OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:17.145539 [ 3863 ] {3eadc6f7-d600-4801-b928-bcd7d031dc10} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal256OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.147227 [ 3863 ] {3eadc6f7-d600-4801-b928-bcd7d031dc10} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.165409 [ 3863 ] {7d86027b-4453-4733-bf45-9aead8aa28b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal256OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.166625 [ 3863 ] {7d86027b-4453-4733-bf45-9aead8aa28b7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.179802 [ 3863 ] {f24a884d-2538-4f44-a797-118557b9b4e5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.180707 [ 3863 ] {f24a884d-2538-4f44-a797-118557b9b4e5} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.192712 [ 3863 ] {2023ffc6-8462-48c7-aa6b-e7ba2b2761fd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal32OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.193881 [ 3863 ] {2023ffc6-8462-48c7-aa6b-e7ba2b2761fd} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal32OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:17.207340 [ 3863 ] {a5279049-4b64-40ca-81fa-ab391580b837} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal32OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.208419 [ 3863 ] {a5279049-4b64-40ca-81fa-ab391580b837} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.221967 [ 3863 ] {88ee9e54-96c0-4867-a4f4-519e382e599f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal32OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.223053 [ 3863 ] {88ee9e54-96c0-4867-a4f4-519e382e599f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.235313 [ 3863 ] {4c982763-5121-4a2f-8f3e-76f8fa284164} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.236337 [ 3863 ] {4c982763-5121-4a2f-8f3e-76f8fa284164} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 3 arguments: In scope SELECT toDecimal64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.262986 [ 3863 ] {08bfbbd3-bf5a-441d-b965-6789b6731180} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal64OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.264509 [ 3863 ] {08bfbbd3-bf5a-441d-b965-6789b6731180} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Array(Nullable(Nothing)): In scope SELECT toDecimal64OrDefault([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:17.469408 [ 3863 ] {e1b41975-e184-4c76-92a2-8731b03895be} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal64OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.470960 [ 3863 ] {e1b41975-e184-4c76-92a2-8731b03895be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.487222 [ 3863 ] {c9c6b6f2-8312-473a-ac7e-35e154a1038a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimal64OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.489002 [ 3863 ] {c9c6b6f2-8312-473a-ac7e-35e154a1038a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.503843 [ 3863 ] {85ee6d82-8096-4795-9966-7ba952d0b40c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toDecimalString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.505225 [ 3863 ] {85ee6d82-8096-4795-9966-7ba952d0b40c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 3, should be 2: In scope SELECT toDecimalString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.519803 [ 3863 ] {24c1b99a-fdc8-41ec-b8b3-da53f1bb9e90} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toFixedString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.520954 [ 3863 ] {24c1b99a-fdc8-41ec-b8b3-da53f1bb9e90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 3, should be 2: In scope SELECT toFixedString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.532642 [ 3863 ] {8f6c4a83-857a-4149-8543-a2374e2c9179} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toFloat32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.633411 [ 3863 ] {8f6c4a83-857a-4149-8543-a2374e2c9179} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.634903 [ 6148 ] {212667a5-31c2-417c-8f3f-f7b61410aaaa} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.dict1 (c35e6ba3-187f-426f-85c1-84f22da810ab), because some tables depend on it: test_krdjlok0.join, test_krdjlok0.t (1028df92-0726-4b20-9013-d248623e36da). (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51302) (comment: 01160_table_dependencies.sh) (in query: detach dictionary dict1 permanently), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000339c1448 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034927a29 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:17.636230 [ 6148 ] {212667a5-31c2-417c-8f3f-f7b61410aaaa} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.dict1 (c35e6ba3-187f-426f-85c1-84f22da810ab), because some tables depend on it: test_krdjlok0.join, test_krdjlok0.t (1028df92-0726-4b20-9013-d248623e36da). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000339c1448 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034927a29 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:17.647987 [ 3863 ] {6600c9ed-c8a5-4e8c-a05f-6a786d2867a5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toFloat32OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.649308 [ 3863 ] {6600c9ed-c8a5-4e8c-a05f-6a786d2867a5} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.755677 [ 3863 ] {a056c651-a456-46e1-9548-ecb7ffc2c934} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toFloat32OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.757178 [ 3863 ] {a056c651-a456-46e1-9548-ecb7ffc2c934} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.772036 [ 3863 ] {8a7d94d4-32ab-4f1b-a088-2d4ca7351eab} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toFloat32OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.773141 [ 3863 ] {8a7d94d4-32ab-4f1b-a088-2d4ca7351eab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.786846 [ 3863 ] {4e76793e-ed37-4a63-a609-b9d191f15a86} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toFloat64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.787863 [ 3863 ] {4e76793e-ed37-4a63-a609-b9d191f15a86} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 3 arguments: In scope SELECT toFloat64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.801893 [ 3863 ] {3bd4c452-c727-4fa6-9a66-433362c42b5b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toFloat64OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.803085 [ 3863 ] {3bd4c452-c727-4fa6-9a66-433362c42b5b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toFloat64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.816023 [ 3863 ] {735abd48-2ff2-4cf7-b4b9-40f3860def11} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toFloat64OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.817121 [ 3863 ] {735abd48-2ff2-4cf7-b4b9-40f3860def11} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.832423 [ 3863 ] {4ab46c5a-5726-4ed5-a3a8-05dd9990c0b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toFloat64OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.833932 [ 3863 ] {4ab46c5a-5726-4ed5-a3a8-05dd9990c0b0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.847950 [ 3863 ] {995a797c-be06-4c58-8503-08c5dfd7a754} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toHour([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.849264 [ 3863 ] {995a797c-be06-4c58-8503-08c5dfd7a754} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.867051 [ 3863 ] {ed8ec564-375b-4fe1-9d0c-9a0c4e01bb8a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIPv4([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.868372 [ 3863 ] {ed8ec564-375b-4fe1-9d0c-9a0c4e01bb8a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv4([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.881295 [ 3863 ] {842a3f61-009c-49f7-aae0-4bf315c5fa9e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIPv4OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.882563 [ 3863 ] {842a3f61-009c-49f7-aae0-4bf315c5fa9e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv4OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.897606 [ 3863 ] {4f819a53-e5e1-4225-8957-40a8b70e4b7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIPv4OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.899049 [ 3863 ] {4f819a53-e5e1-4225-8957-40a8b70e4b7a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.913090 [ 3863 ] {50c640ad-4e83-4b4d-875e-9e9134d51707} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIPv4OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.914631 [ 3863 ] {50c640ad-4e83-4b4d-875e-9e9134d51707} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.929106 [ 3863 ] {f6369f66-47a3-492e-b7d4-246fea9ef0f9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv6([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIPv6([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.930581 [ 3863 ] {f6369f66-47a3-492e-b7d4-246fea9ef0f9} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 3 arguments: In scope SELECT toIPv6([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.945488 [ 3863 ] {9e80518e-0536-49ef-97d0-378581d5f206} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIPv6OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.947087 [ 3863 ] {9e80518e-0536-49ef-97d0-378581d5f206} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toIPv6OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.961308 [ 3863 ] {7da7490d-aff5-459f-87fa-c1217927f42a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIPv6OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.962818 [ 3863 ] {7da7490d-aff5-459f-87fa-c1217927f42a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.979475 [ 3863 ] {5234db37-6067-4ef9-9c05-0bdc8c49aa85} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIPv6OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.981016 [ 3863 ] {5234db37-6067-4ef9-9c05-0bdc8c49aa85} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:17.995477 [ 3863 ] {bb3dc8c5-38d9-40af-9c0f-6cd73005397a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOWeek([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toISOWeek([NULL], [NULL], [NULL]);) 2025.03.31 19:01:17.996783 [ 3863 ] {bb3dc8c5-38d9-40af-9c0f-6cd73005397a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOWeek([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.012382 [ 3863 ] {1d48f189-63a7-457e-9962-5081861953f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toISOYear([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.013553 [ 3863 ] {1d48f189-63a7-457e-9962-5081861953f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toISOYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.026629 [ 3863 ] {b0975301-069a-47de-9c9b-546fb0ec62d4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt128([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.027516 [ 3863 ] {b0975301-069a-47de-9c9b-546fb0ec62d4} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.042388 [ 3863 ] {54c74409-b5df-4a7b-b372-22fbdb6ff1c3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt128OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.043935 [ 3863 ] {54c74409-b5df-4a7b-b372-22fbdb6ff1c3} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt128OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.058181 [ 3863 ] {6466ac35-3a38-4f69-b761-6e72060a81b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt128OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.059563 [ 3863 ] {6466ac35-3a38-4f69-b761-6e72060a81b9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.074746 [ 3863 ] {2040ef20-0d06-4223-9d32-63b81f0824be} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt128OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.076147 [ 3863 ] {2040ef20-0d06-4223-9d32-63b81f0824be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.091827 [ 3863 ] {6cfec23e-1568-433f-ba70-7b92114fb744} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt16([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.093488 [ 3863 ] {6cfec23e-1568-433f-ba70-7b92114fb744} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.116320 [ 3863 ] {a95fe183-2c7e-4110-b459-36913db05abf} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt16OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.117611 [ 3863 ] {a95fe183-2c7e-4110-b459-36913db05abf} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt16OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.132298 [ 3863 ] {0981b5f1-f484-483c-93d0-e76f1e88ceb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt16OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.133907 [ 3863 ] {0981b5f1-f484-483c-93d0-e76f1e88ceb9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.149282 [ 3863 ] {3cf347a0-a6a9-4aa0-9244-c41945f60cdb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt16OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.150819 [ 3863 ] {3cf347a0-a6a9-4aa0-9244-c41945f60cdb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.166128 [ 3863 ] {942abbed-6f81-4b63-85af-987fb3c1226d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt256([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.167375 [ 3863 ] {942abbed-6f81-4b63-85af-987fb3c1226d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.278331 [ 3863 ] {885617d7-0ab8-4ff6-9b99-32874d336c66} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt256OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.279735 [ 3863 ] {885617d7-0ab8-4ff6-9b99-32874d336c66} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt256OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.295170 [ 3863 ] {1c024daf-15e0-440d-9520-070709582ef0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt256OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.296527 [ 3863 ] {1c024daf-15e0-440d-9520-070709582ef0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.312001 [ 3863 ] {fbb8f265-d391-4b64-a298-bf7e5c42d46c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt256OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.313325 [ 3863 ] {fbb8f265-d391-4b64-a298-bf7e5c42d46c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.328015 [ 3863 ] {066682e6-524f-44ce-b6da-f6c5029b7ff1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.329154 [ 3863 ] {066682e6-524f-44ce-b6da-f6c5029b7ff1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.433214 [ 3863 ] {18408ea3-25c7-4d94-b41f-63afcdc899b4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt32OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.434807 [ 3863 ] {18408ea3-25c7-4d94-b41f-63afcdc899b4} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.509652 [ 3863 ] {488d9d1c-735f-45db-a54c-54550c888214} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt32OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.511158 [ 3863 ] {488d9d1c-735f-45db-a54c-54550c888214} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.610609 [ 3863 ] {b2c44155-f3e7-428c-af10-23c94c85e6da} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt32OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.611830 [ 3863 ] {b2c44155-f3e7-428c-af10-23c94c85e6da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.625774 [ 3863 ] {07eb7322-33b6-4294-9bf9-d3014b4f6a0e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.626967 [ 3863 ] {07eb7322-33b6-4294-9bf9-d3014b4f6a0e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.640164 [ 3863 ] {7eccecb4-b7b8-4d64-bceb-cc0fcc9580e6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt64OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.641383 [ 3863 ] {7eccecb4-b7b8-4d64-bceb-cc0fcc9580e6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.774462 [ 3863 ] {db566cd4-87c9-488c-9357-4c313a0015a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt64OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.775901 [ 3863 ] {db566cd4-87c9-488c-9357-4c313a0015a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.879985 [ 3863 ] {a86fb806-a370-43fc-af8b-bab43153c26d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt64OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.881445 [ 3863 ] {a86fb806-a370-43fc-af8b-bab43153c26d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.897913 [ 3863 ] {aeabf05a-e910-4d08-8754-b6c5341daf0c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.899403 [ 3863 ] {aeabf05a-e910-4d08-8754-b6c5341daf0c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.914626 [ 3863 ] {b1fcd04a-284a-4b8e-8af7-3d95faa29989} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt8OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.916130 [ 3863 ] {b1fcd04a-284a-4b8e-8af7-3d95faa29989} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toInt8OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.933924 [ 3863 ] {9c310887-da18-49f7-8b50-c61e5ffb3019} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt8OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.935301 [ 3863 ] {9c310887-da18-49f7-8b50-c61e5ffb3019} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.951700 [ 3863 ] {cb671034-d1d4-4bb0-b7a9-b3367814c751} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toInt8OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.953161 [ 3863 ] {cb671034-d1d4-4bb0-b7a9-b3367814c751} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:18.967568 [ 3863 ] {3e23aef2-0068-4a53-8c47-fefa9246cb82} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIntervalDay([NULL], [NULL], [NULL]);) 2025.03.31 19:01:18.969147 [ 3863 ] {3e23aef2-0068-4a53-8c47-fefa9246cb82} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.001410 [ 3863 ] {241f3038-8dac-480f-a4a3-dc5b2e38738e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIntervalHour([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.002900 [ 3863 ] {241f3038-8dac-480f-a4a3-dc5b2e38738e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.018056 [ 3863 ] {d8229d9c-97be-432e-b799-4a667fd36214} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMicrosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIntervalMicrosecond([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.019516 [ 3863 ] {d8229d9c-97be-432e-b799-4a667fd36214} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMicrosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.039603 [ 3863 ] {7b573fcd-96dd-44ff-a385-01439416a019} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIntervalMillisecond([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.040933 [ 3863 ] {7b573fcd-96dd-44ff-a385-01439416a019} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.057054 [ 3863 ] {86b13677-2aa2-4216-90e7-a08e634b82b5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIntervalMinute([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.157254 [ 3863 ] {86b13677-2aa2-4216-90e7-a08e634b82b5} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.172789 [ 3863 ] {2e0c4178-14dd-42e5-b4c1-a9d6c7c5c72b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIntervalMonth([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.174432 [ 3863 ] {2e0c4178-14dd-42e5-b4c1-a9d6c7c5c72b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.188289 [ 3863 ] {8be97811-77d5-4cc5-98a3-8c7c34b96a0e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalNanosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIntervalNanosecond([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.189568 [ 3863 ] {8be97811-77d5-4cc5-98a3-8c7c34b96a0e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalNanosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.205177 [ 3863 ] {ffbddfba-033b-4e2d-9617-9c97a8b7c3d7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIntervalQuarter([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.206853 [ 3863 ] {ffbddfba-033b-4e2d-9617-9c97a8b7c3d7} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.221835 [ 3863 ] {45072562-620f-4344-8009-95e870882550} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIntervalSecond([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.223177 [ 3863 ] {45072562-620f-4344-8009-95e870882550} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.236886 [ 3863 ] {2f7f3f2d-7658-44f0-89bb-8767fcb20386} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalWeek([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIntervalWeek([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.238416 [ 3863 ] {2f7f3f2d-7658-44f0-89bb-8767fcb20386} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalWeek([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.252007 [ 3863 ] {7ddf5d48-6cd9-4725-a62f-af1244dd06fd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toIntervalYear([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.253466 [ 3863 ] {7ddf5d48-6cd9-4725-a62f-af1244dd06fd} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 3 arguments: In scope SELECT toIntervalYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.266729 [ 3863 ] {eb8fac92-978b-4fdc-b230-21e73eabe156} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toJSONString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.268035 [ 3863 ] {eb8fac92-978b-4fdc-b230-21e73eabe156} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 3, should be 1: In scope SELECT toJSONString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.316205 [ 3863 ] {2dc75c6a-e93c-41a8-9691-e37497074298} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toLastDayOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toLastDayOfMonth([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.317612 [ 3863 ] {2dc75c6a-e93c-41a8-9691-e37497074298} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toLastDayOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.332085 [ 3863 ] {f029d037-0c6a-4fc8-9854-cab4e7985d24} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toLastDayOfWeek([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.333275 [ 3863 ] {f029d037-0c6a-4fc8-9854-cab4e7985d24} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:19.347902 [ 3863 ] {fe071967-282f-4ba3-b43e-ca820c623c4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toLowCardinality([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.349313 [ 3863 ] {fe071967-282f-4ba3-b43e-ca820c623c4b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 3, should be 1: In scope SELECT toLowCardinality([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.363087 [ 3863 ] {c9e7bf24-f395-4d14-86c4-8710234b9fff} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toMillisecond([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.364361 [ 3863 ] {c9e7bf24-f395-4d14-86c4-8710234b9fff} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.378808 [ 3863 ] {f9b41edd-b0af-499b-9587-f152b54b992f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toMinute([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.380016 [ 3863 ] {f9b41edd-b0af-499b-9587-f152b54b992f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.393889 [ 3863 ] {cb05ca0f-3a36-4149-bd00-829ea9ad26f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toModifiedJulianDay([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.395147 [ 3863 ] {cb05ca0f-3a36-4149-bd00-829ea9ad26f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.408686 [ 3863 ] {99250f1f-3d05-4a4c-8754-03686a30f449} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toModifiedJulianDayOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.410245 [ 3863 ] {99250f1f-3d05-4a4c-8754-03686a30f449} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 3, should be 1: In scope SELECT toModifiedJulianDayOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.430605 [ 3830 ] {3156b699-d9e1-4f18-9aa8-5c0042450246} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x00000000083fea57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8cc9 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:01:19.431419 [ 3830 ] {3156b699-d9e1-4f18-9aa8-5c0042450246} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x00000000083fea57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8cc9 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:01:19.488454 [ 3863 ] {b6f8af38-f442-4646-a5f0-37ea0d247036} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonday([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toMonday([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.489854 [ 3863 ] {b6f8af38-f442-4646-a5f0-37ea0d247036} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonday([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.504563 [ 3863 ] {2b6415df-b5b1-4eb7-b5ea-572a1a2a5cf8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toMonth([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.506082 [ 3863 ] {2b6415df-b5b1-4eb7-b5ea-572a1a2a5cf8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.534531 [ 3863 ] {4829b322-9d55-47c2-8bcc-efa785c89299} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toNullable([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.536185 [ 3863 ] {4829b322-9d55-47c2-8bcc-efa785c89299} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 3, should be 1: In scope SELECT toNullable([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.552205 [ 3863 ] {3ab00f30-5fce-4e3f-a8ec-5eb3ab33235b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toQuarter([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.553623 [ 3863 ] {3ab00f30-5fce-4e3f-a8ec-5eb3ab33235b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.568610 [ 3863 ] {614e925d-e8ae-432d-92d8-323f8b10ac2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeDayNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toRelativeDayNum([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.569933 [ 3863 ] {614e925d-e8ae-432d-92d8-323f8b10ac2e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeDayNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.583479 [ 3863 ] {74ec5fb2-09e9-4c87-98bf-db97cc9410fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeHourNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toRelativeHourNum([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.585035 [ 3863 ] {74ec5fb2-09e9-4c87-98bf-db97cc9410fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeHourNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.599363 [ 3863 ] {e5846aff-4e3e-4320-a6af-60f31e52d831} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMinuteNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toRelativeMinuteNum([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.600900 [ 3863 ] {e5846aff-4e3e-4320-a6af-60f31e52d831} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMinuteNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.615623 [ 3863 ] {3f8a8028-a911-4aa4-9da2-cbfca87ba146} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMonthNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toRelativeMonthNum([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.617065 [ 3863 ] {3f8a8028-a911-4aa4-9da2-cbfca87ba146} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeMonthNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.685697 [ 3863 ] {85f30487-2b2e-4e9a-9385-6cd83907234d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeQuarterNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toRelativeQuarterNum([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.687052 [ 3863 ] {85f30487-2b2e-4e9a-9385-6cd83907234d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeQuarterNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.732936 [ 3863 ] {ef22dc1a-6acf-4826-b232-eab6100b5f81} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeSecondNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toRelativeSecondNum([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.734828 [ 3863 ] {ef22dc1a-6acf-4826-b232-eab6100b5f81} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeSecondNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.748530 [ 3863 ] {e5a67968-3974-4a2d-931f-378ab0171461} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeWeekNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toRelativeWeekNum([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.749891 [ 3863 ] {e5a67968-3974-4a2d-931f-378ab0171461} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeWeekNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.762359 [ 3863 ] {49c93ff6-68b6-47d8-bf01-fa6c62478161} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeYearNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toRelativeYearNum([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.763530 [ 3863 ] {49c93ff6-68b6-47d8-bf01-fa6c62478161} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 3, should be 1 or 2: In scope SELECT toRelativeYearNum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.774836 [ 3863 ] {7dbe5030-5b65-445c-9d6c-3a8d8ac51284} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toSecond([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.775899 [ 3863 ] {7dbe5030-5b65-445c-9d6c-3a8d8ac51284} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.788426 [ 3863 ] {ca4be466-a35f-4ecd-bdd6-e20f2a5d8eb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfDay([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.790055 [ 3863 ] {ca4be466-a35f-4ecd-bdd6-e20f2a5d8eb9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfDay([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.804855 [ 3863 ] {5bcce748-4834-4d75-a702-b5e51cec5caa} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfFifteenMinutes([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.806386 [ 3863 ] {5bcce748-4834-4d75-a702-b5e51cec5caa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.819527 [ 3863 ] {62bb6df5-bca3-433c-b0ca-f4b3c5fe40c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfFiveMinute([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.820731 [ 3863 ] {62bb6df5-bca3-433c-b0ca-f4b3c5fe40c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.834103 [ 3863 ] {8e5e9740-47a0-4ce5-9b3a-744788d94082} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfFiveMinutes([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.835465 [ 3863 ] {8e5e9740-47a0-4ce5-9b3a-744788d94082} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfFiveMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.848871 [ 3863 ] {0da0a6f6-9268-4f1d-94e7-b7fe730c4b36} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfHour([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.850908 [ 3863 ] {0da0a6f6-9268-4f1d-94e7-b7fe730c4b36} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfHour([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.865157 [ 3863 ] {7edf9fc9-0434-46a7-8bfb-a697ade9bd15} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfISOYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfISOYear([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.866407 [ 3863 ] {7edf9fc9-0434-46a7-8bfb-a697ade9bd15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfISOYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:19.972549 [ 3863 ] {33e3e65e-64d3-426a-babf-76f9a70f1003} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1st argument of function toStartOfInterval, expected a Date, DateTime or DateTime64: In scope SELECT toStartOfInterval([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfInterval([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.973913 [ 3863 ] {33e3e65e-64d3-426a-babf-76f9a70f1003} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of 1st argument of function toStartOfInterval, expected a Date, DateTime or DateTime64: In scope SELECT toStartOfInterval([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:19.987419 [ 3863 ] {66a9d345-0b56-4d9d-9cda-c5b367d413c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMicrosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfMicrosecond([NULL], [NULL], [NULL]);) 2025.03.31 19:01:19.988784 [ 3863 ] {66a9d345-0b56-4d9d-9cda-c5b367d413c0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMicrosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.002414 [ 3863 ] {85f472fe-99f8-4439-b0a4-f8c28320944e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfMillisecond([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.003670 [ 3863 ] {85f472fe-99f8-4439-b0a4-f8c28320944e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMillisecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.016774 [ 3863 ] {bee7e268-213d-44bb-8e6c-d8cc4a04c0a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfMinute([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.031355 [ 3863 ] {bee7e268-213d-44bb-8e6c-d8cc4a04c0a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMinute([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.046678 [ 3863 ] {13434d5d-9662-4bf0-bfb6-868e84bd5739} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfMonth([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.048094 [ 3863 ] {13434d5d-9662-4bf0-bfb6-868e84bd5739} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfMonth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.062480 [ 3863 ] {078060d8-1f70-4a42-8a76-beccfcac1aa8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfNanosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfNanosecond([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.063899 [ 3863 ] {078060d8-1f70-4a42-8a76-beccfcac1aa8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfNanosecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.161951 [ 3863 ] {0f598813-6df4-427b-97df-1545a500f7b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfQuarter([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.163549 [ 3863 ] {0f598813-6df4-427b-97df-1545a500f7b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfQuarter([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.179089 [ 3863 ] {a30c400a-73e4-4972-8a71-d924e3c4e577} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfSecond([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.180603 [ 3863 ] {a30c400a-73e4-4972-8a71-d924e3c4e577} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfSecond([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.195080 [ 3863 ] {91f89db8-7a98-412c-b8e3-78da13bdaa24} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfTenMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfTenMinutes([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.196468 [ 3863 ] {91f89db8-7a98-412c-b8e3-78da13bdaa24} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfTenMinutes([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.211685 [ 3863 ] {cb385f48-6a9b-40e5-9c85-d8c9a9912cea} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfWeek([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.213186 [ 3863 ] {cb385f48-6a9b-40e5-9c85-d8c9a9912cea} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:20.226387 [ 3863 ] {b028ac65-6d2c-4329-a086-20c4ef125f5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStartOfYear([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.227640 [ 3863 ] {b028ac65-6d2c-4329-a086-20c4ef125f5a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toStartOfYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.241132 [ 3863 ] {33102ed6-ff05-4042-8468-38712ef0bffd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 3 arguments: In scope SELECT toString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.242596 [ 3863 ] {33102ed6-ff05-4042-8468-38712ef0bffd} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 3 arguments: In scope SELECT toString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.257273 [ 3863 ] {25427165-660f-4413-874d-fd51f282422c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toStringCutToZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.259813 [ 3863 ] {25427165-660f-4413-874d-fd51f282422c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 3, should be 1: In scope SELECT toStringCutToZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.282090 [ 3863 ] {05bef094-4d13-4c12-a341-a7766893f292} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 3, should be 1 or 2: In scope SELECT toTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toTime([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.283769 [ 3863 ] {05bef094-4d13-4c12-a341-a7766893f292} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 3, should be 1 or 2: In scope SELECT toTime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.297134 [ 3863 ] {f1b0fa44-9500-4e11-834f-f903e8fcc519} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toTimeZone([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.298541 [ 3863 ] {f1b0fa44-9500-4e11-834f-f903e8fcc519} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimeZone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.311508 [ 3863 ] {49a8471f-bbda-4801-b000-2152ddef794b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toTimezone([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.312717 [ 3863 ] {49a8471f-bbda-4801-b000-2152ddef794b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 3, should be 2: In scope SELECT toTimezone([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.326871 [ 3863 ] {dbac00fc-a12e-44f9-9c64-5c28b2d6daa9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toTypeName([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.328250 [ 3863 ] {dbac00fc-a12e-44f9-9c64-5c28b2d6daa9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 3, should be 1: In scope SELECT toTypeName([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.341659 [ 3863 ] {933f1cb3-f341-4734-9217-4faf63002c9e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt128([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.343216 [ 3863 ] {933f1cb3-f341-4734-9217-4faf63002c9e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt128([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.356429 [ 3863 ] {ecd20f02-bacf-4cb6-9858-12629942299b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt128OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.358024 [ 3863 ] {ecd20f02-bacf-4cb6-9858-12629942299b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt128OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.372934 [ 3863 ] {9ff86cad-bad1-41e2-8206-06964f77db4d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt128OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.374241 [ 3863 ] {9ff86cad-bad1-41e2-8206-06964f77db4d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.388790 [ 3863 ] {a23bba12-9c28-4ccc-b2b9-1302d2aac607} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt128OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.390425 [ 3863 ] {a23bba12-9c28-4ccc-b2b9-1302d2aac607} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.404003 [ 3863 ] {93906f98-5471-427f-92e9-90755d112d15} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt16([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.405218 [ 3863 ] {93906f98-5471-427f-92e9-90755d112d15} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt16([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.418010 [ 3863 ] {25482522-e281-496d-ace1-6d6ae89c87c1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt16OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.419319 [ 3863 ] {25482522-e281-496d-ace1-6d6ae89c87c1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt16OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.476125 [ 3863 ] {7604ffd2-567b-44de-845e-f4d7db5706e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt16OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.477548 [ 3863 ] {7604ffd2-567b-44de-845e-f4d7db5706e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.553859 [ 3863 ] {860c9943-9299-4060-9ff9-6a28bd5244ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt16OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.555475 [ 3863 ] {860c9943-9299-4060-9ff9-6a28bd5244ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.568828 [ 3863 ] {3f8d0b49-23c8-4103-af94-c03743c48c9a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt256([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.570305 [ 3863 ] {3f8d0b49-23c8-4103-af94-c03743c48c9a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt256([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.584914 [ 3863 ] {246b83fa-a935-43b9-a6a3-dd2243047b30} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt256OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.586230 [ 3863 ] {246b83fa-a935-43b9-a6a3-dd2243047b30} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt256OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.599520 [ 3863 ] {3aebfeb9-dc8d-4a7d-af3f-c694b7fb845e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt256OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.600777 [ 3863 ] {3aebfeb9-dc8d-4a7d-af3f-c694b7fb845e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.615290 [ 3863 ] {5e7e5528-cceb-4523-8911-a1cb7af735ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt256OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.616849 [ 3863 ] {5e7e5528-cceb-4523-8911-a1cb7af735ff} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.631421 [ 3863 ] {d043f7f4-0e8b-4b48-ad20-0802b55dca33} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.632799 [ 3863 ] {d043f7f4-0e8b-4b48-ad20-0802b55dca33} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt32([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.646042 [ 3863 ] {cdebee34-49fe-4b5f-bf4f-e10686ea4bd3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt32OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.647240 [ 3863 ] {cdebee34-49fe-4b5f-bf4f-e10686ea4bd3} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt32OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.661241 [ 3863 ] {d5f79e17-c702-445d-b06a-912db3747368} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt32OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.662781 [ 3863 ] {d5f79e17-c702-445d-b06a-912db3747368} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.677104 [ 3863 ] {52d1211a-9f13-4bf3-98d7-30550e3eacf9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt32OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.678655 [ 3863 ] {52d1211a-9f13-4bf3-98d7-30550e3eacf9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.692765 [ 3863 ] {a17c45c9-fcb0-40b0-a9b9-183c050a15da} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.726383 [ 3863 ] {a17c45c9-fcb0-40b0-a9b9-183c050a15da} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt64([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.742192 [ 3863 ] {6ca76ea2-f99f-4dfd-8553-65e70202210f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt64OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.743845 [ 3863 ] {6ca76ea2-f99f-4dfd-8553-65e70202210f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt64OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.758295 [ 3863 ] {3893822c-984b-4bfd-8fb3-0431f0aa4528} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt64OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.759821 [ 3863 ] {3893822c-984b-4bfd-8fb3-0431f0aa4528} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.773940 [ 3863 ] {df74abc8-d8c5-470e-ac31-01de00089860} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt64OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.775515 [ 3863 ] {df74abc8-d8c5-470e-ac31-01de00089860} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.790436 [ 3863 ] {8c567b87-0d73-42cb-bb57-d92362cec83f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.791911 [ 3863 ] {8c567b87-0d73-42cb-bb57-d92362cec83f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 3 arguments: In scope SELECT toUInt8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.805230 [ 3863 ] {aab5e829-76f1-418e-b17c-8b90ef4d2c9c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt8OrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.806707 [ 3863 ] {aab5e829-76f1-418e-b17c-8b90ef4d2c9c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUInt8OrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.820034 [ 3863 ] {3e855dd9-2732-4d35-a4c5-d13eee098632} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt8OrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.821206 [ 3863 ] {3e855dd9-2732-4d35-a4c5-d13eee098632} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.869940 [ 3863 ] {c3dd08a3-e213-46e3-ae59-8861549fab33} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUInt8OrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.871212 [ 3863 ] {c3dd08a3-e213-46e3-ae59-8861549fab33} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.888189 [ 3863 ] {3627bc88-6d51-4019-99a0-ff08aa014b3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUTCTimestamp([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.889617 [ 3863 ] {3627bc88-6d51-4019-99a0-ff08aa014b3f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT toUTCTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.904561 [ 3863 ] {30f9ad74-4581-4b4f-bb68-1fc67e59e23f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 3 arguments: In scope SELECT toUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUUID([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.909666 [ 3863 ] {30f9ad74-4581-4b4f-bb68-1fc67e59e23f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 3 arguments: In scope SELECT toUUID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.922980 [ 3863 ] {1f9761a6-6a7e-4c17-9241-75b7fe3bf958} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUUIDOrDefault([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.924310 [ 3863 ] {1f9761a6-6a7e-4c17-9241-75b7fe3bf958} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUUIDOrDefault([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.937409 [ 3863 ] {e3b0a190-715b-40cc-84eb-57f4e4f8c6fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUUIDOrNull([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.938932 [ 3863 ] {e3b0a190-715b-40cc-84eb-57f4e4f8c6fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.952280 [ 3863 ] {023da080-d40d-41c2-b3b7-62da9fd3e3c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUUIDOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.953558 [ 3863 ] {023da080-d40d-41c2-b3b7-62da9fd3e3c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 3, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.967090 [ 3863 ] {37ab341a-5b12-4f78-8a89-e573843f4b3b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUnixTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUnixTimestamp([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.968376 [ 3863 ] {37ab341a-5b12-4f78-8a89-e573843f4b3b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT toUnixTimestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.981600 [ 3863 ] {f1897a7c-aa6f-4eff-b699-ed9a17fa87e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUnixTimestamp64Micro([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.982948 [ 3863 ] {f1897a7c-aa6f-4eff-b699-ed9a17fa87e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Micro([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:20.995880 [ 3863 ] {28fcf22d-a43c-4c90-8d80-e8ac9274a25f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUnixTimestamp64Milli([NULL], [NULL], [NULL]);) 2025.03.31 19:01:20.997271 [ 3863 ] {28fcf22d-a43c-4c90-8d80-e8ac9274a25f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Milli([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.010800 [ 3863 ] {776c69e7-81a9-4ca6-9430-1b465ab4afbc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toUnixTimestamp64Nano([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.011967 [ 3863 ] {776c69e7-81a9-4ca6-9430-1b465ab4afbc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 3, should be 1: In scope SELECT toUnixTimestamp64Nano([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.025334 [ 3863 ] {ce2e958f-eaae-4b91-83ba-3beceb8d1f58} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toValidUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.026530 [ 3863 ] {ce2e958f-eaae-4b91-83ba-3beceb8d1f58} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 3, should be 1: In scope SELECT toValidUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.039134 [ 3863 ] {6ab3e4c1-5c1e-4e7f-ab7d-1677d783b116} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toWeek([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.040356 [ 3863 ] {6ab3e4c1-5c1e-4e7f-ab7d-1677d783b116} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:21.053468 [ 3863 ] {b4a8853e-3423-47ae-95ce-a5ae1311fd38} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toYYYYMM([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.054858 [ 3863 ] {b4a8853e-3423-47ae-95ce-a5ae1311fd38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMM([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.067118 [ 3863 ] {dfd44bfa-2a63-4ddf-8d11-d55a8f754174} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toYYYYMMDD([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.068275 [ 3863 ] {dfd44bfa-2a63-4ddf-8d11-d55a8f754174} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDD([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.225474 [ 3863 ] {aff30579-5393-4cef-b89e-fdd225670c23} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toYYYYMMDDhhmmss([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.227240 [ 3863 ] {aff30579-5393-4cef-b89e-fdd225670c23} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 3, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.241687 [ 3863 ] {e075c9eb-0787-49d6-baae-56ef0ae04e39} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toYear([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.243236 [ 3863 ] {e075c9eb-0787-49d6-baae-56ef0ae04e39} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 3, should be 1 or 2: In scope SELECT toYear([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.256714 [ 3863 ] {63aca66c-e127-49f5-a9c1-cf652ef8687e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toYearWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT toYearWeek([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.258234 [ 3863 ] {63aca66c-e127-49f5-a9c1-cf652ef8687e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT toYearWeek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:21.282279 [ 2856 ] {09842c3f-2ee7-4afe-83e2-8c908c20633b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42056) (comment: 01656_join_defaul_enum.sql) (in query: DROP DATABASE IF EXISTS test_kyzm4j4h ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:21.283847 [ 2856 ] {09842c3f-2ee7-4afe-83e2-8c908c20633b} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:21.358231 [ 3863 ] {839d202c-9b88-475d-83e0-4abbc9901fde} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT to_utc_timestamp([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.359801 [ 3863 ] {839d202c-9b88-475d-83e0-4abbc9901fde} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 3, should be 2: In scope SELECT to_utc_timestamp([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.374728 [ 3863 ] {893b5b61-d977-44ee-9525-2540ae704e99} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT today([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.376202 [ 3863 ] {893b5b61-d977-44ee-9525-2540ae704e99} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 3, should be 0: In scope SELECT today([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.390639 [ 3863 ] {cb200ff4-47b9-4908-a54b-ccd55684d961} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tokens([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.392063 [ 3863 ] {cb200ff4-47b9-4908-a54b-ccd55684d961} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 3, should be 1: In scope SELECT tokens([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.466102 [ 3830 ] {fc3ea51c-a4cd-4159-8ca8-2c952861196a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDate('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.467029 [ 3830 ] {fc3ea51c-a4cd-4159-8ca8-2c952861196a} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.478051 [ 3830 ] {7f32a026-bb81-4ad4-97b8-b4fb998cf3ea} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDate32('2023-09-11'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.478872 [ 3830 ] {7f32a026-bb81-4ad4-97b8-b4fb998cf3ea} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Date32: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDate32('2023-09-11')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.489073 [ 3830 ] {433a98e1-bb4a-4596-ac60-7688c74b7ae0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDateTime('2023-09-11 12:18:00'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.489926 [ 3830 ] {433a98e1-bb4a-4596-ac60-7688c74b7ae0} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime: In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime('2023-09-11 12:18:00')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.493580 [ 3863 ] {573ff3b6-151c-4e27-b7f9-caa1b3b4c103} executeQuery: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT topK([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.494955 [ 3863 ] {573ff3b6-151c-4e27-b7f9-caa1b3b4c103} TCPHandler: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.500379 [ 3830 ] {0e06d673-278e-4525-a10a-75f54022c00f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(toDateTime64('2023-09-11 12:18:00', 3));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.501083 [ 3830 ] {0e06d673-278e-4525-a10a-75f54022c00f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: DateTime64(3): In scope SELECT YYYYMMDDhhmmssToDateTime64(toDateTime64('2023-09-11 12:18:00', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.508881 [ 3863 ] {983d3442-236f-4296-a178-1869d3d13df0} executeQuery: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT topKWeighted([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.510307 [ 3830 ] {a5ed08f3-08a1-4df0-ac9e-4e9c74b0e6a6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.510629 [ 3863 ] {983d3442-236f-4296-a178-1869d3d13df0} TCPHandler: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.510970 [ 3830 ] {a5ed08f3-08a1-4df0-ac9e-4e9c74b0e6a6} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.520214 [ 3830 ] {0fcaa060-16d1-487b-829d-d4603f37ecd4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11', 'invalid precision'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11', 'invalid precision');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.520891 [ 3830 ] {0fcaa060-16d1-487b-829d-d4603f37ecd4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: String: In scope SELECT YYYYMMDDhhmmssToDateTime64('2023-09-11', 'invalid precision'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f7fba 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:21.524928 [ 3863 ] {8982fa9f-7528-4083-b500-ee31bf31a383} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT topLevelDomain([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.526513 [ 3863 ] {8982fa9f-7528-4083-b500-ee31bf31a383} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 3, should be 1: In scope SELECT topLevelDomain([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.539807 [ 3863 ] {578a4798-57ed-4b56-97cd-337e2ca7b85e} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT topLevelDomainRFC([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.541088 [ 3863 ] {578a4798-57ed-4b56-97cd-337e2ca7b85e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 3, should be 1: In scope SELECT topLevelDomainRFC([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.637766 [ 3863 ] {a882c209-a3a8-4e46-be1d-9a2a157a5f16} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT transactionID([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.639246 [ 3863 ] {a882c209-a3a8-4e46-be1d-9a2a157a5f16} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 3, should be 0: In scope SELECT transactionID([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.653403 [ 3863 ] {5bd24793-bcc5-412d-aa9d-160bb9af8546} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT transactionLatestSnapshot([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.655027 [ 3863 ] {5bd24793-bcc5-412d-aa9d-160bb9af8546} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionLatestSnapshot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.668166 [ 3863 ] {1a96cbad-1ee7-43ee-844f-00ad59ad7f7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT transactionOldestSnapshot([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.669445 [ 3863 ] {1a96cbad-1ee7-43ee-844f-00ad59ad7f7c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 3, should be 0: In scope SELECT transactionOldestSnapshot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.682076 [ 3863 ] {737a2202-144f-4ab4-a414-3d9935d9a902} executeQuery: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types.: In scope SELECT transform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT transform([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.683288 [ 3863 ] {737a2202-144f-4ab4-a414-3d9935d9a902} TCPHandler: Code: 43. DB::Exception: Function transform has signature: transform(T, Array(T), Array(U), U) -> U; or transform(T, Array(T), Array(T)) -> T; where T and U are types.: In scope SELECT transform([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:21.695444 [ 3863 ] {84436b28-ed0d-4ae9-b531-21ca5c2bc03c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function translate: In scope SELECT translate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT translate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.696398 [ 6149 ] {0748a7fd-69f7-42ef-b481-9800f25e5a4a} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.dict1, because some tables depend on it: test_krdjlok0.join, test_krdjlok0.t (1028df92-0726-4b20-9013-d248623e36da). (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44136) (comment: 01160_table_dependencies.sh) (in query: rename database test_krdjlok0 to test_krdjlok0_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c41f9 6. ./src/Interpreters/StorageID.h:35: DB::DatabaseAtomic::renameDatabase(std::shared_ptr, String const&) @ 0x0000000032993fc6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000034bbfbea 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbc06a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:01:21.696650 [ 3863 ] {84436b28-ed0d-4ae9-b531-21ca5c2bc03c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function translate: In scope SELECT translate([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:21.698255 [ 6149 ] {0748a7fd-69f7-42ef-b481-9800f25e5a4a} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.dict1, because some tables depend on it: test_krdjlok0.join, test_krdjlok0.t (1028df92-0726-4b20-9013-d248623e36da). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c41f9 6. ./src/Interpreters/StorageID.h:35: DB::DatabaseAtomic::renameDatabase(std::shared_ptr, String const&) @ 0x0000000032993fc6 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterRenameQuery::executeToDatabase(DB::ASTRenameQuery const&, std::vector> const&) @ 0x0000000034bbfbea 8. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:75: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbc06a 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:01:21.709391 [ 3863 ] {3b66e942-b3c4-4e04-ad28-fdac53a0ee43} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function translateUTF8: In scope SELECT translateUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT translateUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.710757 [ 3863 ] {3b66e942-b3c4-4e04-ad28-fdac53a0ee43} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function translateUTF8: In scope SELECT translateUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:21.778563 [ 3863 ] {7f05b632-9d9f-40da-b249-c6aa6b0d1c51} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 3, should be 1: In scope SELECT trimBoth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT trimBoth([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.779955 [ 3863 ] {7f05b632-9d9f-40da-b249-c6aa6b0d1c51} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 3, should be 1: In scope SELECT trimBoth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.893365 [ 3863 ] {a5b6a5f5-6efa-4be7-9a18-05bd142b3ee7} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 3, should be 1: In scope SELECT trimLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT trimLeft([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.895053 [ 3863 ] {a5b6a5f5-6efa-4be7-9a18-05bd142b3ee7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 3, should be 1: In scope SELECT trimLeft([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.909280 [ 3863 ] {dc68458c-f138-4595-9c38-d20b78139e8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 3, should be 1: In scope SELECT trimRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT trimRight([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.910542 [ 3863 ] {dc68458c-f138-4595-9c38-d20b78139e8c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 3, should be 1: In scope SELECT trimRight([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.923936 [ 3863 ] {3ff33762-32c9-49c2-a6d6-d758d103b40c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trunc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT trunc([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.925397 [ 3863 ] {3ff33762-32c9-49c2-a6d6-d758d103b40c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT trunc([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.938337 [ 3863 ] {f72bb97d-59d1-480d-9cf5-5d5eb9086f26} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT truncate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT truncate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.939628 [ 3863 ] {f72bb97d-59d1-480d-9cf5-5d5eb9086f26} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 3 arguments: In scope SELECT truncate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.953123 [ 3863 ] {45897589-2b91-4ce2-aea6-7268ee50830a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tryBase58Decode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.954665 [ 3863 ] {45897589-2b91-4ce2-aea6-7268ee50830a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase58Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.968046 [ 3863 ] {6cc312eb-4ef7-428a-a57e-bb2a8bf49a88} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tryBase64Decode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.969343 [ 3863 ] {6cc312eb-4ef7-428a-a57e-bb2a8bf49a88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 3, should be 1: In scope SELECT tryBase64Decode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.982603 [ 3863 ] {f6e578db-c179-4e61-b278-967732ae722e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tryBase64URLDecode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:21.983974 [ 3863 ] {f6e578db-c179-4e61-b278-967732ae722e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 3, should be 1: In scope SELECT tryBase64URLDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:21.996391 [ 3863 ] {97b732b0-a57d-4263-a7c9-ab3f5b7eea07} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'tryDecrypt'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT tryDecrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tryDecrypt([NULL], '[HIDDEN]')) 2025.03.31 19:01:21.997902 [ 3863 ] {97b732b0-a57d-4263-a7c9-ab3f5b7eea07} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'mode' to function 'tryDecrypt'. Expected: decryption mode string, got: Array(Nullable(Nothing)): In scope SELECT tryDecrypt([NULL], '[HIDDEN]'). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:22.011790 [ 3863 ] {46d35a18-9e8d-436e-8bdb-e7eb974dd8b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tryIdnaEncode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.013183 [ 3863 ] {46d35a18-9e8d-436e-8bdb-e7eb974dd8b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 3, should be 1: In scope SELECT tryIdnaEncode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.104950 [ 3863 ] {8ec06f2b-5979-4044-b2bc-689dcfca4442} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tryPunycodeDecode([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.106622 [ 3863 ] {8ec06f2b-5979-4044-b2bc-689dcfca4442} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 3, should be 1: In scope SELECT tryPunycodeDecode([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.120847 [ 3863 ] {1492f3ed-b407-4abe-aada-4beeb7731001} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumble. Should be a date with time: In scope SELECT tumble([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tumble([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.122315 [ 3863 ] {1492f3ed-b407-4abe-aada-4beeb7731001} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumble. Should be a date with time: In scope SELECT tumble([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:22.136127 [ 3863 ] {14a9b4df-6f3f-4bd3-8de4-84a3e97e4cfc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumbleEnd. Should be a date with time: In scope SELECT tumbleEnd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tumbleEnd([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.137403 [ 3863 ] {14a9b4df-6f3f-4bd3-8de4-84a3e97e4cfc} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumbleEnd. Should be a date with time: In scope SELECT tumbleEnd([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:22.150616 [ 3863 ] {58ef8976-7fc5-4f2e-9d86-f31bcd6685c9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumbleStart. Should be a date with time: In scope SELECT tumbleStart([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tumbleStart([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.152001 [ 3863 ] {58ef8976-7fc5-4f2e-9d86-f31bcd6685c9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function tumbleStart. Should be a date with time: In scope SELECT tumbleStart([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:22.189655 [ 3863 ] {a1a77c83-7ae7-4fae-a9ea-02e5ce651ff5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function tupleConcat: In scope SELECT tupleConcat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleConcat([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.191084 [ 3863 ] {a1a77c83-7ae7-4fae-a9ea-02e5ce651ff5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument 1 of function tupleConcat: In scope SELECT tupleConcat([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:22.203070 [ 3863 ] {aff1926c-997f-4c12-84c5-08fcb27c9685} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleDivide([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.208126 [ 3863 ] {aff1926c-997f-4c12-84c5-08fcb27c9685} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 3, should be 2: In scope SELECT tupleDivide([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.220268 [ 3863 ] {f8e112c1-06ff-49b9-8480-3de359bb33af} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleDivideByNumber([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.221455 [ 3863 ] {f8e112c1-06ff-49b9-8480-3de359bb33af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleDivideByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.282047 [ 3863 ] {e23ac39f-ef40-481b-ac48-82678895de3b} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Array(Nullable(Nothing)): In scope SELECT tupleElement([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleElement([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.283888 [ 3863 ] {e23ac39f-ef40-481b-ac48-82678895de3b} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Array(Nullable(Nothing)): In scope SELECT tupleElement([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:22.297909 [ 3863 ] {b41eca1a-6501-4af1-ace9-b4614a78d901} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleHammingDistance([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.299377 [ 3863 ] {b41eca1a-6501-4af1-ace9-b4614a78d901} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 3, should be 2: In scope SELECT tupleHammingDistance([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.312112 [ 3863 ] {47584a01-810c-4aa0-a930-f25bb5ad9d61} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleIntDiv([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.313285 [ 3863 ] {47584a01-810c-4aa0-a930-f25bb5ad9d61} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 3, should be 2: In scope SELECT tupleIntDiv([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.326049 [ 3863 ] {dc13d331-f485-43ab-85f2-2bb55d495772} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleIntDivByNumber([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.327305 [ 3863 ] {dc13d331-f485-43ab-85f2-2bb55d495772} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.339596 [ 3863 ] {28e0d747-ff04-4a5e-afbf-1833f50c163d} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleIntDivOrZero([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.340841 [ 3863 ] {28e0d747-ff04-4a5e-afbf-1833f50c163d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZero([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.408092 [ 3863 ] {d3e66c0f-722c-414b-9614-d3611fc380a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleIntDivOrZeroByNumber([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.409294 [ 3863 ] {d3e66c0f-722c-414b-9614-d3611fc380a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleIntDivOrZeroByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.422663 [ 3863 ] {942100ad-0f15-4727-ac7f-9ecb7b0b7f37} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleMinus([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.423846 [ 3863 ] {942100ad-0f15-4727-ac7f-9ecb7b0b7f37} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT tupleMinus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.435333 [ 3863 ] {c59030d3-4d46-47a1-bc75-7fb6be94b4e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleModulo([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.436716 [ 3863 ] {c59030d3-4d46-47a1-bc75-7fb6be94b4e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 3, should be 2: In scope SELECT tupleModulo([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.448288 [ 3863 ] {b3604a9d-9876-4db2-b8c1-e6c5cb6a12c8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleModuloByNumber([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.449423 [ 3863 ] {b3604a9d-9876-4db2-b8c1-e6c5cb6a12c8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleModuloByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.466850 [ 3863 ] {cbe6a1cd-4a3b-431d-aed1-5001a5f3e9f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleMultiply([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.468261 [ 3863 ] {cbe6a1cd-4a3b-431d-aed1-5001a5f3e9f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 3, should be 2: In scope SELECT tupleMultiply([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.480052 [ 3863 ] {59e4fb80-4642-4498-a932-dad9c3b5c18b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleMultiplyByNumber([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.481345 [ 3863 ] {59e4fb80-4642-4498-a932-dad9c3b5c18b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 3, should be 2: In scope SELECT tupleMultiplyByNumber([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.537580 [ 3863 ] {1d420530-bf73-49d7-b181-6267d8db4ca7} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleNames([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.538792 [ 3863 ] {1d420530-bf73-49d7-b181-6267d8db4ca7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 3, should be 1: In scope SELECT tupleNames([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.550091 [ 3863 ] {a41b3ab8-0e9c-4f7c-bb4b-191454a217e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleNegate([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.551313 [ 3863 ] {a41b3ab8-0e9c-4f7c-bb4b-191454a217e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 3, should be 1: In scope SELECT tupleNegate([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.562551 [ 3863 ] {47e559bc-85f3-4da7-9fa1-1b01e1d288e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tuplePlus([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.563918 [ 3863 ] {47e559bc-85f3-4da7-9fa1-1b01e1d288e3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT tuplePlus([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.577244 [ 3863 ] {af85e15f-3b3e-4fed-a100-c0db0ce391a7} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT tupleToNameValuePairs([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.578635 [ 3863 ] {af85e15f-3b3e-4fed-a100-c0db0ce391a7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 3, should be 1: In scope SELECT tupleToNameValuePairs([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.591088 [ 3863 ] {dc726b52-8a90-430f-b87c-325a0980e91e} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT ucase([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.592269 [ 3863 ] {dc726b52-8a90-430f-b87c-325a0980e91e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT ucase([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.604602 [ 3863 ] {580b36db-c4d7-4c40-a9ff-5d16f2c190ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT unbin([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.606234 [ 3863 ] {580b36db-c4d7-4c40-a9ff-5d16f2c190ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 3, should be 1: In scope SELECT unbin([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.618181 [ 3863 ] {15b95a68-1ce9-4ad2-b517-8172da4dbf0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT unhex([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.619400 [ 3863 ] {15b95a68-1ce9-4ad2-b517-8172da4dbf0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 3, should be 1: In scope SELECT unhex([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.793401 [ 3863 ] {aa562ad7-b8bc-4da3-8e0d-ea18e7f8d0ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT uniqThetaIntersect([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.795104 [ 3863 ] {aa562ad7-b8bc-4da3-8e0d-ea18e7f8d0ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 3, should be 2: In scope SELECT uniqThetaIntersect([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.808398 [ 3863 ] {566cbbad-0a77-45a6-b46e-2c74bf1827d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT uniqThetaNot([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.843479 [ 3863 ] {566cbbad-0a77-45a6-b46e-2c74bf1827d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 3, should be 2: In scope SELECT uniqThetaNot([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.854771 [ 3863 ] {2199c58b-df28-40ee-8cf7-ebbc74a7bb09} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT uniqThetaUnion([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.855903 [ 3863 ] {2199c58b-df28-40ee-8cf7-ebbc74a7bb09} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 3, should be 2: In scope SELECT uniqThetaUnion([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.897280 [ 3863 ] {3c5ca0a8-3f12-4228-8a18-4667ee3ce5ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT upper([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.898682 [ 3863 ] {3c5ca0a8-3f12-4228-8a18-4667ee3ce5ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 3, should be 1: In scope SELECT upper([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.911236 [ 3863 ] {13c6d94c-94a4-40e8-9100-58c2d075870b} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT upperUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.912389 [ 3863 ] {13c6d94c-94a4-40e8-9100-58c2d075870b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 3, should be 1: In scope SELECT upperUTF8([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.923701 [ 3863 ] {f85e2cae-2a27-4e49-b3c9-b8ea74262ee0} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT uptime([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.924822 [ 3863 ] {f85e2cae-2a27-4e49-b3c9-b8ea74262ee0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 3, should be 0: In scope SELECT uptime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.936455 [ 3863 ] {03cf17a8-1f85-4766-b81a-92859989d1d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT user([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.937541 [ 3863 ] {03cf17a8-1f85-4766-b81a-92859989d1d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 3, should be 0: In scope SELECT user([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.948267 [ 3863 ] {b5822b7c-0030-460e-9df0-c0d26f78e700} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function validateNestedArraySizes Must be UInt.: In scope SELECT validateNestedArraySizes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT validateNestedArraySizes([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.949367 [ 3863 ] {b5822b7c-0030-460e-9df0-c0d26f78e700} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of first argument of function validateNestedArraySizes Must be UInt.: In scope SELECT validateNestedArraySizes([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:22.960349 [ 3863 ] {2cc022b9-7975-4207-a169-736a9f11f0b3} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT varPop([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.961443 [ 3863 ] {2cc022b9-7975-4207-a169-736a9f11f0b3} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.972224 [ 3863 ] {34b99dc7-6340-4f02-b003-8f1a81e1d3fa} executeQuery: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT varPopStable([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.973259 [ 3863 ] {34b99dc7-6340-4f02-b003-8f1a81e1d3fa} TCPHandler: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.984698 [ 3863 ] {3808be81-f2b0-478e-a9ca-934378b62c11} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT varSamp([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.985917 [ 3863 ] {3808be81-f2b0-478e-a9ca-934378b62c11} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:22.996879 [ 3863 ] {70f457df-8d5d-448d-a0f1-caeb0c59fb5e} executeQuery: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT varSampStable([NULL], [NULL], [NULL]);) 2025.03.31 19:01:22.998298 [ 3863 ] {70f457df-8d5d-448d-a0f1-caeb0c59fb5e} TCPHandler: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.010798 [ 3863 ] {8672fb2b-9e4d-49d1-b532-ff792446317a} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Array(Nullable(Nothing)): In scope SELECT variantElement([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT variantElement([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.012027 [ 3863 ] {8672fb2b-9e4d-49d1-b532-ff792446317a} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Array(Nullable(Nothing)): In scope SELECT variantElement([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:23.023972 [ 3863 ] {0c8747cc-332b-476e-9c49-a9dc15d1b08d} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT variantType([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.025137 [ 3863 ] {0c8747cc-332b-476e-9c49-a9dc15d1b08d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 3, should be 1: In scope SELECT variantType([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.059892 [ 6109 ] {f885456e-81b6-490c-9a17-450331194cfe} executeQuery: Code: 81. DB::Exception: Database test_krdjlok0_2 does not exist. Maybe you meant test_krdjlok0?. (UNKNOWN_DATABASE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44156) (comment: 01160_table_dependencies.sh) (in query: rename table t to test_krdjlok0_2.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:664: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000003399e286 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:155: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc2597 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbc095 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:23.061351 [ 6109 ] {f885456e-81b6-490c-9a17-450331194cfe} TCPHandler: Code: 81. DB::Exception: Database test_krdjlok0_2 does not exist. Maybe you meant test_krdjlok0?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:664: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x000000003399e286 5. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:155: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x0000000034bc2597 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000034bbc095 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:23.116315 [ 3863 ] {1f569b16-6bd5-4775-a47c-585211e3b41a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT vectorDifference([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.118208 [ 3863 ] {1f569b16-6bd5-4775-a47c-585211e3b41a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 3, should be 2: In scope SELECT vectorDifference([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.131458 [ 3863 ] {4a6b3f68-a53c-465c-b9ad-213d93a05449} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT vectorSum([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.132993 [ 3863 ] {4a6b3f68-a53c-465c-b9ad-213d93a05449} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 3, should be 2: In scope SELECT vectorSum([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.144128 [ 3863 ] {7a9b2827-75b3-416a-acc7-cbe0a281007c} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT version([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.145313 [ 3863 ] {7a9b2827-75b3-416a-acc7-cbe0a281007c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 3, should be 0: In scope SELECT version([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.155402 [ 3830 ] {21b1c0c5-4446-47ed-b8c4-e932ba6ec011} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'precision' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8035 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:23.156346 [ 3830 ] {21b1c0c5-4446-47ed-b8c4-e932ba6ec011} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'precision' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: const String, got: UInt8: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000084006a7 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x00000000083f98e1 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8035 6. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:01:23.156721 [ 3863 ] {a8ada4fb-9059-4a6c-97be-b7a2faeb6412} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT visibleWidth([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.158218 [ 3863 ] {a8ada4fb-9059-4a6c-97be-b7a2faeb6412} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 3, should be 1: In scope SELECT visibleWidth([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.170481 [ 3863 ] {c0c5e62b-9b4a-44cd-88af-3bcfc231bd6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT visitParamExtractBool([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.171863 [ 3863 ] {c0c5e62b-9b4a-44cd-88af-3bcfc231bd6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractBool([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.184260 [ 3863 ] {cac27b00-655f-4e5e-a40c-cec204124470} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT visitParamExtractFloat([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.186286 [ 3863 ] {cac27b00-655f-4e5e-a40c-cec204124470} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractFloat([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.198598 [ 3863 ] {43c5e529-f743-458a-b588-a2ad38c94eeb} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT visitParamExtractInt([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.199909 [ 3863 ] {43c5e529-f743-458a-b588-a2ad38c94eeb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.212663 [ 3863 ] {49321e69-e566-4e63-9390-b480702381ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT visitParamExtractRaw([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.221078 [ 3863 ] {49321e69-e566-4e63-9390-b480702381ba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractRaw([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.283025 [ 6107 ] {d578ae35-5c22-413c-bbbf-292ebbc3704a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39956) (comment: 02784_projections_read_in_order_bug.sql) (in query: DROP DATABASE IF EXISTS test_y925u4rs ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:23.284343 [ 6107 ] {d578ae35-5c22-413c-bbbf-292ebbc3704a} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:23.296202 [ 6194 ] {797a70a0-3638-407e-9506-5bd7b5d5e5ab} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39958) (comment: 02784_projections_read_in_order_bug.sql) (in query: DROP DATABASE IF EXISTS test_y925u4rs ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:23.297928 [ 6194 ] {797a70a0-3638-407e-9506-5bd7b5d5e5ab} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:23.310253 [ 3922 ] {5f655a35-9d5f-40aa-9ff0-20cdffc4866d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39972) (comment: 02784_projections_read_in_order_bug.sql) (in query: DROP DATABASE IF EXISTS test_y925u4rs ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:23.311724 [ 3922 ] {5f655a35-9d5f-40aa-9ff0-20cdffc4866d} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:23.315421 [ 3863 ] {d49b0d42-7145-4cd5-b850-399edad52590} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT visitParamExtractString([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.316985 [ 3863 ] {d49b0d42-7145-4cd5-b850-399edad52590} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractString([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.329089 [ 6194 ] {c929d8a5-1532-4059-bbeb-f802bebac421} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39984) (comment: 02784_projections_read_in_order_bug.sql) (in query: DROP DATABASE IF EXISTS test_y925u4rs ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:23.330208 [ 3863 ] {43fbbf79-b4a4-42fc-8c19-8ef5778804c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT visitParamExtractUInt([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.330736 [ 6194 ] {c929d8a5-1532-4059-bbeb-f802bebac421} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:23.331563 [ 3863 ] {43fbbf79-b4a4-42fc-8c19-8ef5778804c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 3, should be 2: In scope SELECT visitParamExtractUInt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.344021 [ 3863 ] {3bd0f587-3e38-4bc8-a8c2-681e9c29bd84} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT visitParamHas([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.345217 [ 3863 ] {3bd0f587-3e38-4bc8-a8c2-681e9c29bd84} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 3, should be 2: In scope SELECT visitParamHas([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.516679 [ 3863 ] {4946d577-9df2-42c9-8d45-c9b3a3f439f7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT week([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT week([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.518224 [ 3863 ] {4946d577-9df2-42c9-8d45-c9b3a3f439f7} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT week([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:23.531307 [ 3863 ] {7ab3ea86-9844-4662-ac51-542f8dda59e4} executeQuery: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT welchTTest([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.532648 [ 3863 ] {7ab3ea86-9844-4662-ac51-542f8dda59e4} TCPHandler: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.544141 [ 3863 ] {642b4b9a-3a06-4eb4-a31e-426ce48e9aa4} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT widthBucket([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.545390 [ 3863 ] {642b4b9a-3a06-4eb4-a31e-426ce48e9aa4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT widthBucket([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.558609 [ 3863 ] {45763a84-5233-47de-8d73-c4cf817db837} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT width_bucket([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.560019 [ 3863 ] {45763a84-5233-47de-8d73-c4cf817db837} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 3, should be 4: In scope SELECT width_bucket([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.653097 [ 3863 ] {75397fe9-f4de-460c-a103-3558c9915f2e} executeQuery: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT windowFunnel([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.654685 [ 3863 ] {75397fe9-f4de-460c-a103-3558c9915f2e} TCPHandler: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.714689 [ 3863 ] {252c329b-718b-490d-a7e2-02675cb8ec99} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function windowID. Should be a date with time: In scope SELECT windowID([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT windowID([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.716032 [ 3863 ] {252c329b-718b-490d-a7e2-02675cb8ec99} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function windowID. Should be a date with time: In scope SELECT windowID([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:23.727339 [ 3863 ] {098513ae-0286-4c32-9b72-1098739f61c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wkt([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.728575 [ 3863 ] {098513ae-0286-4c32-9b72-1098739f61c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 3, should be 1: In scope SELECT wkt([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:23.739930 [ 3863 ] {b718e250-666d-4a53-99eb-efa47dc19072} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleMinHash([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.741141 [ 3863 ] {b718e250-666d-4a53-99eb-efa47dc19072} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:23.838824 [ 3863 ] {8990665b-7369-4494-b878-556a77bedb06} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleMinHashArg([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.840068 [ 3863 ] {8990665b-7369-4494-b878-556a77bedb06} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArg([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:23.944697 [ 3863 ] {76eb8684-c572-4d4a-8bff-ba3861df7883} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleMinHashArgCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.946242 [ 3863 ] {76eb8684-c572-4d4a-8bff-ba3861df7883} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:23.960335 [ 3863 ] {fbccedac-a186-45d4-9d8e-dcb8fec7d99c} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.962003 [ 3863 ] {fbccedac-a186-45d4-9d8e-dcb8fec7d99c} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:23.976708 [ 3863 ] {ebab3e59-b0ab-4074-9281-fa9bcd0d5475} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleMinHashArgUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.978312 [ 3863 ] {ebab3e59-b0ab-4074-9281-fa9bcd0d5475} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashArgUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:23.990429 [ 3863 ] {6b3839e0-c4ce-4963-b644-a1608048a685} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleMinHashCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:23.991693 [ 3863 ] {6b3839e0-c4ce-4963-b644-a1608048a685} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:24.003343 [ 3863 ] {d3b4bd2e-fcdf-4d96-98d9-4d13bd8d6d3a} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.004596 [ 3863 ] {d3b4bd2e-fcdf-4d96-98d9-4d13bd8d6d3a} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:24.016574 [ 3863 ] {dca2126f-dec8-45a3-bc10-7dd2e217cd4c} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleMinHashUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.018051 [ 3863 ] {dca2126f-dec8-45a3-bc10-7dd2e217cd4c} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleMinHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:24.030075 [ 3863 ] {62b625be-9be2-498a-895d-73dc1ae82e99} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleSimHash([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.031461 [ 3863 ] {62b625be-9be2-498a-895d-73dc1ae82e99} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHash([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:24.043720 [ 3863 ] {e408e87d-e64f-487e-9f99-e353bad5ade4} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleSimHashCaseInsensitive([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.044997 [ 3863 ] {e408e87d-e64f-487e-9f99-e353bad5ade4} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashCaseInsensitive([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:24.056551 [ 3863 ] {784252df-5711-4c76-84ab-07c6ed1288fa} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.057672 [ 3863 ] {784252df-5711-4c76-84ab-07c6ed1288fa} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashCaseInsensitiveUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:24.070345 [ 3863 ] {c4d37d62-f02f-4112-8a6b-d46f4e5f56b0} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wordShingleSimHashUTF8([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.071761 [ 3863 ] {c4d37d62-f02f-4112-8a6b-d46f4e5f56b0} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Array(Nullable(Nothing)): In scope SELECT wordShingleSimHashUTF8([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:24.083973 [ 3863 ] {2aeb90d1-fa4a-46be-bca9-bfc1cf9294e7} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT wyHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT wyHash64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.085207 [ 3863 ] {2aeb90d1-fa4a-46be-bca9-bfc1cf9294e7} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT wyHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:24.096847 [ 3863 ] {8bad27dd-cbc1-4ea5-a12f-93d3c0c5270f} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function xor: In scope SELECT xor([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT xor([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.098111 [ 3863 ] {8bad27dd-cbc1-4ea5-a12f-93d3c0c5270f} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nullable(Nothing))) of 1 argument of function xor: In scope SELECT xor([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:24.110054 [ 3863 ] {285663af-38ad-4a03-a6a0-c6b05115d49f} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT xxHash32([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT xxHash32([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.111369 [ 3863 ] {285663af-38ad-4a03-a6a0-c6b05115d49f} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT xxHash32([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:24.123251 [ 3863 ] {7fa68888-afc5-4e35-92e9-1bb708363067} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT xxHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT xxHash64([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.124431 [ 3863 ] {7fa68888-afc5-4e35-92e9-1bb708363067} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT xxHash64([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:24.136508 [ 3863 ] {559325a1-6dfb-46df-9e7d-c9cec02cbbbe} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT xxh3([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT xxh3([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.137824 [ 3863 ] {559325a1-6dfb-46df-9e7d-c9cec02cbbbe} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Nullable(Nothing) in case if value is NULL: In scope SELECT xxh3([NULL], [NULL], [NULL]). (NOT_IMPLEMENTED) 2025.03.31 19:01:24.148560 [ 3863 ] {e6fec9d6-13e4-43e1-b02b-69d04fe3e03b} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT yandexConsistentHash([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.181921 [ 3863 ] {e6fec9d6-13e4-43e1-b02b-69d04fe3e03b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 3, should be 2: In scope SELECT yandexConsistentHash([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:24.193664 [ 3863 ] {738c961c-c29a-4f57-a62b-58436cb2c457} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT yearweek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT yearweek([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.195175 [ 3863 ] {738c961c-c29a-4f57-a62b-58436cb2c457} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nullable(Nothing)) of argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64: In scope SELECT yearweek([NULL], [NULL], [NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:01:24.206214 [ 3863 ] {18ff1f9f-1336-4ae4-872e-124b2da1af7b} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT yesterday([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.207398 [ 3863 ] {18ff1f9f-1336-4ae4-872e-124b2da1af7b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 3, should be 0: In scope SELECT yesterday([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:24.217984 [ 3863 ] {06f9ff5e-9800-465b-8a0f-dbd858b860dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45578) (comment: 00534_functions_bad_arguments13.sh) (in query: SELECT zookeeperSessionUptime([NULL], [NULL], [NULL]);) 2025.03.31 19:01:24.219146 [ 3863 ] {06f9ff5e-9800-465b-8a0f-dbd858b860dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 3, should be 0: In scope SELECT zookeeperSessionUptime([NULL], [NULL], [NULL]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:01:24.459878 [ 6194 ] {2f567d77-6d05-4773-867d-9971f11043a8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40012) (comment: 02187_test_final_and_limit_modifier.sql) (in query: DROP DATABASE IF EXISTS test_by1lhr8a ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:24.461259 [ 6194 ] {2f567d77-6d05-4773-867d-9971f11043a8} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:24.869203 [ 3830 ] {2a0a7e87-f6f8-4c46-9219-14c2575ab634} executeQuery: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'invalid tz'). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'invalid tz');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe1c87 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd2f16 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000003236d99a 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000003236e5b2 8. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String&, void>(std::allocator const&, unsigned int&, String&) @ 0x0000000015fa6a1b 9. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6355 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 2025.03.31 19:01:24.870393 [ 3830 ] {2a0a7e87-f6f8-4c46-9219-14c2575ab634} TCPHandler: Code: 36. DB::Exception: Cannot load time zone invalid tz: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'invalid tz'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000001ffe1c87 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DateLUT::getImplementation(String const&) const @ 0x000000001ffd2f16 6. ./src/Common/DateLUT.h:0: TimezoneMixin::TimezoneMixin(String const&) @ 0x000000003236d99a 7. ./build_docker/./src/DataTypes/DataTypeDateTime64.cpp:0: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x000000003236e5b2 8. std::shared_ptr std::allocate_shared[abi:v15007], unsigned int&, String&, void>(std::allocator const&, unsigned int&, String&) @ 0x0000000015fa6a1b 9. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6355 10. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 2025.03.31 19:01:24.882535 [ 3830 ] {b4651170-7cb5-4a14-b699-c07b09a2d514} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'Europe/Berlin', 'no more args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'Europe/Berlin', 'no more args');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x00000000083fea57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8cc9 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:01:24.883433 [ 3830 ] {b4651170-7cb5-4a14-b699-c07b09a2d514} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 4 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(20230911134254, 3, 'Europe/Berlin', 'no more args'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x00000000083fea57 4. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x00000000083f8cc9 5. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::getReturnTypeImpl(std::vector> const&) const @ 0x0000000015fa6036 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:01:25.536119 [ 3922 ] {67401034-0ffd-4758-8402-23cb34bb190b} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44208) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:25.537343 [ 3922 ] {67401034-0ffd-4758-8402-23cb34bb190b} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:26.646425 [ 3137 ] {} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339b83d8 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339b942e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339da35f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 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*) @ 0x00000000319a464f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:26.832976 [ 6149 ] {b30f52ac-20d1-4b06-b5a3-55dbaff5a5c5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44232) (comment: 00902_entropy.sql) (in query: select val < 2.4 and val > 2.3393 from (select entropy(vals) as val from defaults);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:01:26.835108 [ 6149 ] {b30f52ac-20d1-4b06-b5a3-55dbaff5a5c5} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:01:27.775499 [ 3830 ] {eb05fe32-6f9b-488f-b36c-10ffa1998af3} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(nan). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(NaN);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa55b2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:27.776496 [ 3830 ] {eb05fe32-6f9b-488f-b36c-10ffa1998af3} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(nan). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa55b2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:27.786722 [ 3830 ] {014bb403-be9b-47ba-81e0-37a34972d675} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(inf). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa55b2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:27.787412 [ 3830 ] {014bb403-be9b-47ba-81e0-37a34972d675} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa55b2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:27.796642 [ 3830 ] {46c7a538-8a8f-429d-92e0-8e5bb326f182} executeQuery: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(-inf). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(-Inf);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa55b2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:27.797549 [ 3830 ] {46c7a538-8a8f-429d-92e0-8e5bb326f182} TCPHandler: Code: 36. DB::Exception: Argument for function YYYYMMDDhhmmssToDateTime64 must be finite: In scope SELECT YYYYMMDDhhmmssToDateTime64(-inf). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionYYYYMMDDhhmmssToDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000015fa55b2 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:27.892431 [ 3922 ] {437502d8-d7b8-4b1f-9b56-e3448f9d6623} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44322) (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_exclusive', 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:27.894569 [ 3922 ] {437502d8-d7b8-4b1f-9b56-e3448f9d6623} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:28.413095 [ 3830 ] {a95dca78-d914-451f-b033-d6fd7d0fe44d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37564) (comment: 02876_yyyymmddhhmmsstodatetime.sql) (in query: SELECT YYYYMMDDhhmmssToDateTime64(20230900111111);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:28.414275 [ 3830 ] {a95dca78-d914-451f-b033-d6fd7d0fe44d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=724). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:28.737371 [ 3596 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f7684ad4-5a51-47e0-b9af-e4cdeab38f3a::202503_1_20_4}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:28.914986 [ 3830 ] {8a01a2f9-4fcb-4e20-b568-dc86c2232ec4} 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.10457.altinitytest (altinity build)) (from [::1]:44366) (comment: 00071_merge_tree_optimize_aio.sql) (in query: INSERT INTO test.hits_snippet(EventTime, EventDate, CounterID, UserID, URL, Referer) SELECT EventTime, EventDate, CounterID, UserID, URL, Referer FROM test.hits WHERE EventDate = toDate('2014-03-18') ORDER BY EventTime, EventDate, CounterID, UserID, URL, Referer ASC LIMIT 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae5cf59 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:01:28.918641 [ 3830 ] {8a01a2f9-4fcb-4e20-b568-dc86c2232ec4} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae5cf59 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:01:29.250782 [ 6194 ] {314d7b0d-9b0a-4ed5-8b25-7629b3d5694f} executeQuery: Code: 57. DB::Exception: Table test_15.distinct_in_order already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44372) (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 = 0.1173417717218399, 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 = 261899821, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 5987087, merge_max_block_size = 7956, old_parts_lifetime = 135., 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 = 10737418240, concurrent_part_removal_threshold = 30, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 50032, primary_key_compress_block_size = 59809), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:29.252215 [ 6194 ] {314d7b0d-9b0a-4ed5-8b25-7629b3d5694f} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:29.807550 [ 3831 ] {d6aac0ad-8f83-4376-8186-d6161a03eedd} 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.10457.altinitytest (altinity build)) (from [::1]:55058) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:01:29.810982 [ 3831 ] {d6aac0ad-8f83-4376-8186-d6161a03eedd} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:01:29.868787 [ 4240 ] {64238894-10e6-4b5a-a0f2-57ef7bfdb957} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44394) (comment: 01160_table_dependencies.sh) (in query: drop dictionary dict2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:29.870313 [ 4240 ] {64238894-10e6-4b5a-a0f2-57ef7bfdb957} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:31.641667 [ 3831 ] {4ca31871-f9fe-46e7-b7e2-f7d1a554b081} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55960) (comment: 00147_global_in_aggregate_function.sql) (in query: SELECT sum(`__table2`.`UserID` GLOBAL IN (`_data_10951897634536988111_737910315569362019` AS `__table1`)) AS `sum(globalIn(UserID, _subquery_1))` FROM `test`.`hits` AS `__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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:01:31.644258 [ 3831 ] {4ca31871-f9fe-46e7-b7e2-f7d1a554b081} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:01:32.054994 [ 4240 ] {96bacab3-a06d-4bea-a487-5fa6592d5794} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55098) (comment: 00147_global_in_aggregate_function.sql) (in query: SELECT sum(UserID GLOBAL IN (SELECT UserID FROM test.hits)) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8bfc78 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:01:32.058740 [ 4240 ] {96bacab3-a06d-4bea-a487-5fa6592d5794} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 : 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8bfc78 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:01:32.223385 [ 3831 ] {c3c94747-e663-445d-baf4-7bad91e479ec} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55128) (comment: 00270_views_query_processing_stage.sql) (in query: DROP TABLE view1_00270;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:32.224976 [ 3831 ] {c3c94747-e663-445d-baf4-7bad91e479ec} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:32.762241 [ 4240 ] {4250252e-7e29-43c3-898f-6f178db3603b} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.join (c30b82ea-d4c6-40a4-8bb7-8a8a8f60cd70), because some tables depend on it: test_krdjlok0.s, test_krdjlok0.dict2. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55150) (comment: 01160_table_dependencies.sh) (in query: drop table join;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c41f9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034929042 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:32.763499 [ 4240 ] {4250252e-7e29-43c3-898f-6f178db3603b} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.join (c30b82ea-d4c6-40a4-8bb7-8a8a8f60cd70), because some tables depend on it: test_krdjlok0.s, test_krdjlok0.dict2. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c41f9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034929042 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:33.500736 [ 3831 ] {c066d257-4658-4b1f-8be7-f5d9499f1537} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55200) (comment: 01160_table_dependencies.sh) (in query: drop dictionary dict1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:33.502082 [ 3831 ] {c066d257-4658-4b1f-8be7-f5d9499f1537} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:33.737391 [ 6149 ] {bd390690-f0e6-436f-a15c-1b2496203972} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35902) (comment: 00270_views_query_processing_stage.sql) (in query: DROP DATABASE IF EXISTS test_2cdtkkk6 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:33.738878 [ 6149 ] {bd390690-f0e6-436f-a15c-1b2496203972} DynamicQueryHandler: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:34.213901 [ 3831 ] {126cd703-9f21-4762-8da0-9a402a9a5bb0} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.dict_src (a1f2f0d8-c0fb-45df-afcd-10f539772f2b), because some tables depend on it: test_krdjlok0.dict1. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55234) (comment: 01160_table_dependencies.sh) (in query: drop table dict_src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c41f9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034929042 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:34.215413 [ 3831 ] {126cd703-9f21-4762-8da0-9a402a9a5bb0} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_krdjlok0.dict_src (a1f2f0d8-c0fb-45df-afcd-10f539772f2b), because some tables depend on it: test_krdjlok0.dict1. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c41f9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034929042 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:36.534123 [ 4240 ] {986d6e7f-7d74-4e57-8307-5ae253e3cae3} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonAreaCartesian([]). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55248) (comment: 01308_polygon_area.sql) (in query: SELECT polygonAreaCartesian([]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionPolygonArea>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6f743b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:36.535033 [ 4240 ] {986d6e7f-7d74-4e57-8307-5ae253e3cae3} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonAreaCartesian([]). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionPolygonArea>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a6f743b 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:01:37.386331 [ 2854 ] {1d7efea6-5c1d-4a69-9fe7-05bc79d84082} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55344) (comment: 01040_h3_get_resolution.sql) (in query: SELECT h3GetResolution(621807531097128959);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:37.388419 [ 2854 ] {1d7efea6-5c1d-4a69-9fe7-05bc79d84082} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:38.994669 [ 6107 ] {4f123b9c-56d6-44f1-b9c8-54e8e71ffb10} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55402) (comment: 02179_range_hashed_dictionary_invalid_interval.sql) (in query: DROP DICTIONARY 02179_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:38.996029 [ 6107 ] {4f123b9c-56d6-44f1-b9c8-54e8e71ffb10} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:01:39.904315 [ 2856 ] {5c0fc1c5-0a71-4122-a927-5373ed1b37c2} executeQuery: Code: 57. DB::Exception: Table test.hits_1m already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55002) (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 = 6049, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 138577519, compact_parts_max_granules_to_buffer = 113, compact_parts_merge_max_bytes_to_prefetch_part = 13242509, merge_max_block_size = 13869, old_parts_lifetime = 166., 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 = 7468121900, index_granularity_bytes = 20579244, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 18527, primary_key_compress_block_size = 99716), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:39.907592 [ 2856 ] {5c0fc1c5-0a71-4122-a927-5373ed1b37c2} TCPHandler: Code: 57. DB::Exception: Table test.hits_1m 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:40.077308 [ 3831 ] {4fd2bdf7-73d7-4473-9606-9e0113d74104} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52186) (comment: 02179_range_hashed_dictionary_invalid_interval.sql) (in query: DROP DATABASE IF EXISTS test_k5z0sbas ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:01:40.079054 [ 3831 ] {4fd2bdf7-73d7-4473-9606-9e0113d74104} DynamicQueryHandler: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:01:41.358031 [ 2856 ] {489952f5-f697-4173-b599-d1523c288092} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55010) (comment: 01890_stem.sql) (in query: SELECT stem('fr', 'dépasser');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:41.359809 [ 2856 ] {489952f5-f697-4173-b599-d1523c288092} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:45.458065 [ 6148 ] {6d62a4b9-53dc-4a2a-9b42-951db5a68516} 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.10457.altinitytest (altinity build)) (from [::1]:55074) (comment: 00701_rollup.sql) (in query: SELECT a, b, sum(s), count() from rollup GROUP BY ROLLUP(a, b) WITH TOTALS ORDER BY a, b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:01:45.461512 [ 6148 ] {6d62a4b9-53dc-4a2a-9b42-951db5a68516} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:01:50.458174 [ 6148 ] {02784_automatic_parallel_replicas-test_1_whole_table_10M_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60644) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:50.460692 [ 6148 ] {02784_automatic_parallel_replicas-test_1_whole_table_10M_pure} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:01:52.354165 [ 6107 ] {02784_automatic_parallel_replicas-test_1_whole_table_6M_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60658) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6cade 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&) @ 0x0000000034d531f4 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf7a3e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 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*) @ 0x000000003589fd91 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:01:52.356188 [ 6107 ] {02784_automatic_parallel_replicas-test_1_whole_table_6M_pure} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6cade 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&) @ 0x0000000034d531f4 12. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf7a3e 13. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 14. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 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*) @ 0x000000003589fd91 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:01:57.583697 [ 3863 ] {2bb0a1f8-7460-404f-b345-90b53fcd016d} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60710) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:01:57.585094 [ 3863 ] {2bb0a1f8-7460-404f-b345-90b53fcd016d} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:01:58.212264 [ 6194 ] {8c896dcf-e153-4532-8a7a-f928f475e188} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60722) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:01:58.213905 [ 6194 ] {8c896dcf-e153-4532-8a7a-f928f475e188} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:01:58.901555 [ 6194 ] {5f205246-79ff-46b8-961f-8133e5b66aba} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60724) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:01:58.908627 [ 6194 ] {5f205246-79ff-46b8-961f-8133e5b66aba} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:01:59.123893 [ 3863 ] {07705f28-11b6-45c8-8081-6fec74866882} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47856) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(`__table1`.`number`) AS `sum(number)` FROM `test_1`.`test_parallel_replicas_automatic_count` AS `__table1` WHERE `__table1`.`p` != 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:01:59.126105 [ 3863 ] {07705f28-11b6-45c8-8081-6fec74866882} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:01:59.577954 [ 6107 ] {02784_automatic_parallel_replicas-test_1_pruning_1M_pure} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60718) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count WHERE p != 3 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8b1e39 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032349251 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:01:59.582964 [ 6107 ] {02784_automatic_parallel_replicas-test_1_pruning_1M_pure} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 : 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8b1e39 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032349251 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:01:59.602296 [ 6194 ] {5b246f89-c909-47ea-a5d7-72cfc9ce23b1} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57456) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:01:59.603811 [ 6194 ] {5b246f89-c909-47ea-a5d7-72cfc9ce23b1} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:00.370975 [ 3922 ] {1583016a-cf93-473d-9bd8-e74282b2822f} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57474) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:00.372352 [ 3922 ] {1583016a-cf93-473d-9bd8-e74282b2822f} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:01.093334 [ 3922 ] {ba1a7655-7603-4b80-a189-6d402ef4d20e} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57484) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:01.189526 [ 3922 ] {ba1a7655-7603-4b80-a189-6d402ef4d20e} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:01.819197 [ 3922 ] {e55667e9-60c9-48fb-9aa9-95af7b438f18} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57492) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:01.820660 [ 3922 ] {e55667e9-60c9-48fb-9aa9-95af7b438f18} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:02.568813 [ 3922 ] {3019f206-95bd-4fff-b741-0bff483a435e} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57498) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:02.571032 [ 3922 ] {3019f206-95bd-4fff-b741-0bff483a435e} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:02.679286 [ 6194 ] {02784_automatic_parallel_replicas-test_1_pruning_500k_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57466) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count WHERE p != 3 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c01ed8e 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf3b8f4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 27. ? @ 0x00007f038ce47ac3 28. ? @ 0x00007f038ced9850 2025.03.31 19:02:02.687822 [ 6194 ] {02784_automatic_parallel_replicas-test_1_pruning_500k_pure} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:199: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c01ed8e 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf3b8f4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 27. ? @ 0x00007f038ce47ac3 28. ? @ 0x00007f038ced9850 2025.03.31 19:02:03.246128 [ 6194 ] {b684b7c1-3ba8-4009-b5cf-18656346131f} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57500) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:03.247956 [ 6194 ] {b684b7c1-3ba8-4009-b5cf-18656346131f} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:03.910757 [ 6194 ] {b73ee86c-f218-4551-ad1e-90425747319a} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57512) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:03.912401 [ 6194 ] {b73ee86c-f218-4551-ad1e-90425747319a} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:04.650781 [ 3830 ] {8097684b-79e7-4a45-8587-da0703494425} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57524) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:04.652286 [ 3830 ] {8097684b-79e7-4a45-8587-da0703494425} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:05.310132 [ 3830 ] {ecfef481-e9dc-4cd7-aa96-7d570dd6c0a1} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57532) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:05.311718 [ 3830 ] {ecfef481-e9dc-4cd7-aa96-7d570dd6c0a1} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:05.499181 [ 4240 ] {237b642b-38c6-47ee-9ae8-f43deee4c998} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51118) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(`__table1`.`number`) AS `sum(number)` FROM `test_1`.`test_parallel_replicas_automatic_count` AS `__table1` WHERE `__table1`.`number` < 500000), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:02:05.501384 [ 4240 ] {237b642b-38c6-47ee-9ae8-f43deee4c998} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:02:05.534242 [ 6194 ] {02784_automatic_parallel_replicas-test_1_index_100k_pure} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57526) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count WHERE number < 500_000 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8b1e39 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032349251 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:02:05.540087 [ 6194 ] {02784_automatic_parallel_replicas-test_1_index_100k_pure} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.9:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 : 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8b1e39 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032349251 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:02:06.049835 [ 6194 ] {f4455475-299b-43b5-a38d-4f437cde8633} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57534) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:06.051265 [ 6194 ] {f4455475-299b-43b5-a38d-4f437cde8633} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:06.308369 [ 3830 ] {02784_automatic_parallel_replicas-test_1_limit_10M_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57542) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(number) FROM (SELECT number FROM test_parallel_replicas_automatic_count LIMIT 1_000_000) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:02:06.311203 [ 3830 ] {02784_automatic_parallel_replicas-test_1_limit_10M_pure} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:02:06.686473 [ 6194 ] {03923f03-c5b7-4359-9e3e-290aefe813a1} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57546) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:06.688222 [ 6194 ] {03923f03-c5b7-4359-9e3e-290aefe813a1} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:07.300986 [ 3830 ] {afa8dca4-51bb-47f4-b3de-ca858ece541c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57560) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:07.302405 [ 3830 ] {afa8dca4-51bb-47f4-b3de-ca858ece541c} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:08.027782 [ 3830 ] {c05b9d11-fb2b-4f41-892a-06342be70763} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57564) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:08.029281 [ 3830 ] {c05b9d11-fb2b-4f41-892a-06342be70763} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:08.816834 [ 3830 ] {b1e7b7df-164b-4a20-9db9-b783b598a2a7} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57568) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:08.818382 [ 3830 ] {b1e7b7df-164b-4a20-9db9-b783b598a2a7} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:09.377825 [ 6194 ] {02784_automatic_parallel_replicas-test_1_limit_1M_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57554) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(number) FROM (SELECT number FROM test_parallel_replicas_automatic_count LIMIT 1_000_000) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c028754 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf3b8f4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 27. ? @ 0x00007f038ce47ac3 28. ? @ 0x00007f038ced9850 2025.03.31 19:02:09.383518 [ 6194 ] {02784_automatic_parallel_replicas-test_1_limit_1M_pure} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c028754 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf3b8f4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 27. ? @ 0x00007f038ce47ac3 28. ? @ 0x00007f038ced9850 2025.03.31 19:02:09.453146 [ 3830 ] {483f7afa-43b7-4af9-a770-9d30675e0130} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54094) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:09.454962 [ 3830 ] {483f7afa-43b7-4af9-a770-9d30675e0130} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:10.074098 [ 3830 ] {a23033d9-fb9f-4b9b-9ba9-7a315e214576} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54110) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:10.076121 [ 3830 ] {a23033d9-fb9f-4b9b-9ba9-7a315e214576} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:10.762865 [ 6194 ] {70163f6e-fb60-4c2f-8249-4a66e06e7c55} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54126) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:10.764677 [ 6194 ] {70163f6e-fb60-4c2f-8249-4a66e06e7c55} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:10.903853 [ 3830 ] {02784_automatic_parallel_replicas-test_1_useless_limit_500k_pure} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54132) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count LIMIT 1_000_000 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:02:10.908055 [ 3830 ] {02784_automatic_parallel_replicas-test_1_useless_limit_500k_pure} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:02:11.442979 [ 6194 ] {189e1b8b-1ce5-41d0-8513-0e9dfb19ee7c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54144) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:11.444521 [ 6194 ] {189e1b8b-1ce5-41d0-8513-0e9dfb19ee7c} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:12.045424 [ 6194 ] {3c61825d-8f0f-4dd8-aa50-902690766162} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54156) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:12.047056 [ 6194 ] {3c61825d-8f0f-4dd8-aa50-902690766162} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:12.809954 [ 6194 ] {6c83a4c1-a410-4cc7-ab17-f8d6c15e76df} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54168) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:12.811358 [ 6194 ] {6c83a4c1-a410-4cc7-ab17-f8d6c15e76df} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:13.492473 [ 4240 ] {3036bcd2-0d7a-46de-9a85-06fb56ca06b1} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54182) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:13.493928 [ 4240 ] {3036bcd2-0d7a-46de-9a85-06fb56ca06b1} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:14.139886 [ 4240 ] {8a051162-5d38-4f20-aac2-b7594fd5cd5a} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54186) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:14.141310 [ 4240 ] {8a051162-5d38-4f20-aac2-b7594fd5cd5a} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:14.409366 [ 4240 ] {16243621-158d-41e3-9506-34d8bc3fb120} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59764) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(`__table1`.`number`) AS `sum(number)` FROM `test_1`.`test_parallel_replicas_automatic_count` AS `__table1` WHERE (`__table1`.`number` + `__table1`.`p`) = 42), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:02:14.412220 [ 4240 ] {16243621-158d-41e3-9506-34d8bc3fb120} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:02:14.441856 [ 6194 ] {02784_automatic_parallel_replicas-test_1_helpless_filter_5M_pure} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=731). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54176) (comment: 02784_parallel_replicas_automatic_decision.sh) (in query: SELECT sum(number) FROM test_parallel_replicas_automatic_count WHERE number + p = 42 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8b1e39 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032349251 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:02:14.447405 [ 6194 ] {02784_automatic_parallel_replicas-test_1_helpless_filter_5M_pure} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=731). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 : 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000003a8b1e39 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000032349251 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:02:14.779696 [ 6194 ] {b7e25423-609c-4bd1-8117-1c6b17d9410c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54200) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:14.781177 [ 6194 ] {b7e25423-609c-4bd1-8117-1c6b17d9410c} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:15.429064 [ 4240 ] {57ac8d54-4175-426f-a3e1-5d6607853ba2} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54216) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:15.430644 [ 4240 ] {57ac8d54-4175-426f-a3e1-5d6607853ba2} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:16.061434 [ 4240 ] {e3e9e8ee-76c3-4d05-b613-708fc17a677d} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54232) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:16.062969 [ 4240 ] {e3e9e8ee-76c3-4d05-b613-708fc17a677d} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:16.729603 [ 4240 ] {6e735229-cfd0-4fe1-bafe-0045be678fe0} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54248) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:16.731476 [ 4240 ] {6e735229-cfd0-4fe1-bafe-0045be678fe0} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:17.406422 [ 4240 ] {02c4a09a-6d4c-414d-ad0e-47a8834d4440} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54260) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:17.408156 [ 4240 ] {02c4a09a-6d4c-414d-ad0e-47a8834d4440} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:18.119835 [ 4240 ] {2c59cb75-5ffa-422b-b5c9-899ee2ba69ee} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54276) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:18.121600 [ 4240 ] {2c59cb75-5ffa-422b-b5c9-899ee2ba69ee} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:18.778745 [ 6194 ] {27f8b8b7-5abc-4989-841b-6043b92df74b} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54280) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:18.780186 [ 6194 ] {27f8b8b7-5abc-4989-841b-6043b92df74b} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:19.438517 [ 4240 ] {da1e384a-7b60-487a-b9c4-fa930487dee8} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40052) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:19.440162 [ 4240 ] {da1e384a-7b60-487a-b9c4-fa930487dee8} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:20.102195 [ 4240 ] {14c31b4e-44b2-4043-aa54-0b2099101386} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40070) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:20.103593 [ 4240 ] {14c31b4e-44b2-4043-aa54-0b2099101386} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:20.810625 [ 4240 ] {a87a6e0f-58ca-415f-93dd-0f59f41900ea} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40096) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:20.812627 [ 4240 ] {a87a6e0f-58ca-415f-93dd-0f59f41900ea} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:21.522488 [ 6194 ] {0b291f36-ee8d-457c-8358-2622af4ff453} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40102) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:21.524042 [ 6194 ] {0b291f36-ee8d-457c-8358-2622af4ff453} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:22.132481 [ 4240 ] {bd964762-bc80-43f4-9fc7-f205a1f16639} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40118) (comment: 02500_remove_redundant_distinct.sh) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:22.134228 [ 4240 ] {bd964762-bc80-43f4-9fc7-f205a1f16639} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:25.691226 [ 6194 ] {48908f8f-9f64-40f4-bcce-eadd25aaca0a} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument of function toTimezone. Should be DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTimeZone(N, 'UTC') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toTimeZone(N, 'UTC') as r FORMAT CSV;) 2025.03.31 19:02:25.692196 [ 6194 ] {48908f8f-9f64-40f4-bcce-eadd25aaca0a} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument of function toTimezone. Should be DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTimeZone(N, 'UTC') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:26.837654 [ 4240 ] {1450e5c1-86ca-4caf-a873-5f3985e70a9a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40128) (comment: 02210_processors_profile_log.sql) (in query: WITH ( SELECT query_id FROM system.query_log WHERE current_database = currentDatabase() AND Settings['log_processors_profiles']='1' ) AS query_id_ SELECT name, multiIf( -- ExpressionTransform executes sleep(), -- so IProcessor::work() will spend 1 sec. -- We use two different timers to measure time: CLOCK_MONOTONIC for sleep and CLOCK_MONOTONIC_COARSE for profiling -- that's why we cannot compare directly with 1,000,000 microseconds - let's compare with 900,000 microseconds. name = 'ExpressionTransform', elapsed_us >= 0.9e6 ? 1 : elapsed_us, -- SourceFromSingleChunk, that feed data to ExpressionTransform, -- will feed first block and then wait in PortFull. name = 'SourceFromSingleChunk', output_wait_elapsed_us >= 0.9e6 ? 1 : output_wait_elapsed_us, -- NullSource/LazyOutputFormatLazyOutputFormat are the outputs -- so they cannot starts to execute before sleep(1) will be executed. input_wait_elapsed_us>=1e6 ? 1 : input_wait_elapsed_us) elapsed, input_rows, input_bytes, output_rows, output_bytes FROM system.processors_profile_log WHERE query_id = query_id_ ORDER BY name;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c028754 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf3b8f4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 27. ? @ 0x00007f038ce47ac3 28. ? @ 0x00007f038ced9850 2025.03.31 19:02:26.842831 [ 4240 ] {1450e5c1-86ca-4caf-a873-5f3985e70a9a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:144: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c028754 15. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:37: DB::MergeTreeThreadSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf3b8f4 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 25. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 27. ? @ 0x00007f038ce47ac3 28. ? @ 0x00007f038ced9850 2025.03.31 19:02:28.494365 [ 6194 ] {f52ec1b3-fade-4985-a4aa-258f85350595} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:28.495318 [ 6194 ] {f52ec1b3-fade-4985-a4aa-258f85350595} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:28.801874 [ 6194 ] {adde5c68-6c58-4ba9-82d7-16481ffd3a35} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:28.802687 [ 6194 ] {adde5c68-6c58-4ba9-82d7-16481ffd3a35} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:29.040137 [ 6194 ] {c7793843-597a-4263-86bd-eaf448fddbaa} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toSecond: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:29.041181 [ 6194 ] {c7793843-597a-4263-86bd-eaf448fddbaa} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toSecond: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toSecond(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:29.394387 [ 4240 ] {ec7c6318-1fa9-475b-96a8-e63babcf4745} executeQuery: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (TOO_MANY_PARTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40134) (comment: 01593_insert_settings.sql) (in query: insert into data_01593 select * from numbers_mt(10) settings max_partitions_per_insert_block=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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7db54a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:95: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039eecd1b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a398f3e 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb0c944 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7e5f69 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7e5a76 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7e4727 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 14. ./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*) @ 0x000000003ae5cf59 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:02:29.396238 [ 4240 ] {ec7c6318-1fa9-475b-96a8-e63babcf4745} TCPHandler: Code: 252. DB::Exception: Too many partitions for single INSERT block (more than 1). The limit is controlled by 'max_partitions_per_insert_block' setting. Large number of partitions is a common misconception. It will lead to severe negative performance impact, including slow server startup, slow INSERT queries and slow SELECT queries. Recommended total number of partitions for a table is under 1000..10000. Please note, that partitioning is not intended to speed up SELECT queries (ORDER BY key is sufficient to make range queries fast). Partitions are intended for data manipulation (DROP PARTITION, etc). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000a7db54a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:95: DB::MergeTreeDataWriter::splitBlockIntoParts(DB::Block&&, unsigned long, std::shared_ptr const&, std::shared_ptr, std::shared_ptr) @ 0x0000000039eecd1b 5. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000003a398f3e 6. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000003bb0c944 7. ./src/Common/CollectionOfDerived.h:28: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7e5f69 8. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7e5a76 9. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7e4727 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 14. ./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*) @ 0x000000003ae5cf59 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:02:29.427140 [ 5378 ] {3cb5f619-402d-4dc1-8875-3f1823a52760} MergeTreeDataWriter: INSERT query from initial_user default (query ID: 3cb5f619-402d-4dc1-8875-3f1823a52760) inserted a block that created parts in 10 partitions. This is being logged rather than throwing an exception as throw_on_max_partitions_per_insert_block=false. 2025.03.31 19:02:29.873068 [ 6194 ] {c2775c88-c72e-4e0a-a585-0440b2b42234} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:29.874038 [ 6194 ] {c2775c88-c72e-4e0a-a585-0440b2b42234} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:30.062299 [ 5920 ] {} test_eeyq99pe.data_01593 (29b8cd6e-0150-4585-a869-c572ca9acab1): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.03.31 19:02:30.245037 [ 6194 ] {bc6f69bb-0aba-4567-93c0-b6e2f386c385} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfISOYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:30.245853 [ 6194 ] {bc6f69bb-0aba-4567-93c0-b6e2f386c385} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfISOYear is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfISOYear(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:30.702731 [ 6194 ] {ea896586-ef9c-40df-834c-d54f00ce63f4} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:30.703835 [ 6194 ] {ea896586-ef9c-40df-834c-d54f00ce63f4} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfQuarter is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfQuarter(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:31.013615 [ 5920 ] {} DatabaseCatalog: Cannot drop table test_eeyq99pe.data_01593 (29b8cd6e-0150-4585-a869-c572ca9acab1). Will retry later.: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 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>*) @ 0x00000000397276a1 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>*) @ 0x0000000039720472 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2997: DB::MergeTreeData::dropAllData() @ 0x0000000039736baa 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2cda53 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339b9fe2 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339daaa3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303ec68c 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()() @ 0x00000000303ec46d 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b123d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303eeb6e 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:02:31.131329 [ 6194 ] {cf92ec62-7f89-448b-aef5-3ddee0ba472e} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:31.132317 [ 6194 ] {cf92ec62-7f89-448b-aef5-3ddee0ba472e} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfMonth is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMonth(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:31.613156 [ 6194 ] {9fb5f9a3-1259-4941-9688-92b19e7b7b41} executeQuery: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:31.614371 [ 6194 ] {9fb5f9a3-1259-4941-9688-92b19e7b7b41} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toMonday is allowed only when the 1st argument has the type DateTime or DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toMonday(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:31.908015 [ 6194 ] {8ce5dd90-d2d4-401e-b7fc-69123007ab07} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:31.909091 [ 6194 ] {8ce5dd90-d2d4-401e-b7fc-69123007ab07} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:31.949413 [ 6194 ] {63d2bd6c-713b-451b-9b55-26791cfe3fd5} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:31.950507 [ 6194 ] {63d2bd6c-713b-451b-9b55-26791cfe3fd5} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:31.990324 [ 6194 ] {605ce985-3304-474a-93aa-0983aa2a8660} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:31.991157 [ 6194 ] {605ce985-3304-474a-93aa-0983aa2a8660} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toStartOfWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toStartOfWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:32.721915 [ 6194 ] {d1fc7fd9-4f5e-4c70-a6b9-1525242afc78} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:32.722843 [ 6194 ] {d1fc7fd9-4f5e-4c70-a6b9-1525242afc78} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfHour: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfHour(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:33.025563 [ 6194 ] {b435c63a-ca3a-4730-9d4c-4ed877b85690} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:33.026436 [ 6194 ] {b435c63a-ca3a-4730-9d4c-4ed877b85690} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfMinute: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfMinute(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:33.302116 [ 6194 ] {b2ea91f2-45e2-4042-91e0-575720a94eae} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFiveMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:33.303032 [ 6194 ] {b2ea91f2-45e2-4042-91e0-575720a94eae} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFiveMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFiveMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:33.858593 [ 6194 ] {13dfcd91-871f-42ec-82a0-93f35ec64f66} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfTenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:33.859477 [ 6194 ] {13dfcd91-871f-42ec-82a0-93f35ec64f66} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfTenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfTenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:34.270250 [ 6194 ] {3009c3f6-80fe-427f-85a5-6465bf1aa3e8} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFifteenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:34.271050 [ 6194 ] {3009c3f6-80fe-427f-85a5-6465bf1aa3e8} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfFifteenMinutes: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfFifteenMinutes(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:34.587051 [ 6194 ] {059a61c4-d2e5-49f1-82be-0d3933a92203} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfInterval with interval type Year is allowed only when the 1st argument has type DateTime or DateTimt64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalYear(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 1 year, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:34.588053 [ 6194 ] {059a61c4-d2e5-49f1-82be-0d3933a92203} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfInterval with interval type Year is allowed only when the 1st argument has type DateTime or DateTimt64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalYear(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:34.990304 [ 6194 ] {8b164574-bd70-4b1f-8ac2-a4658c60ab97} executeQuery: Code: 43. DB::Exception: The timezone argument of function toStartOfInterval with interval type Month is allowed only when the 1st argument has type DateTime or DateTimt64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMonth(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 1 month, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:34.991426 [ 6194 ] {8b164574-bd70-4b1f-8ac2-a4658c60ab97} TCPHandler: Code: 43. DB::Exception: The timezone argument of function toStartOfInterval with interval type Month is allowed only when the 1st argument has type DateTime or DateTimt64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMonth(1), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:35.771297 [ 6194 ] {d6d67675-19c0-4bed-977b-254ed0f0c432} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfInterval: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMinute(15), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toStartOfInterval(N, INTERVAL 15 minute, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:35.772134 [ 6194 ] {d6d67675-19c0-4bed-977b-254ed0f0c432} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfInterval: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toStartOfInterval(N, toIntervalMinute(15), 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:35.999391 [ 6194 ] {3fc27eaa-231f-4c5c-9de2-844036251829} executeQuery: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'year' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:36.000266 [ 6194 ] {3fc27eaa-231f-4c5c-9de2-844036251829} TCPHandler: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'year' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('year', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:36.292876 [ 6194 ] {62e44dfe-0ead-4dfe-8e7a-232faf9a832e} executeQuery: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'month' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:36.293683 [ 6194 ] {62e44dfe-0ead-4dfe-8e7a-232faf9a832e} TCPHandler: Code: 43. DB::Exception: The timezone argument of function dateTrunc with datepart 'month' is allowed only when the 2nd argument has the type DateTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('month', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:36.597138 [ 6194 ] {b7d8a4fe-865a-4149-ae78-135fc9fac7c7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), date_trunc('day', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:36.598090 [ 6194 ] {b7d8a4fe-865a-4149-ae78-135fc9fac7c7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:02:36.917133 [ 3600 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {77a8a2d0-78b3-4ff5-a9ae-1a8661deb8ca::202503_1_15_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:02:36.971151 [ 6194 ] {91959a95-0e26-4da0-818f-e13cc4503b0d} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument for function dateTrunc: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:36.972066 [ 6194 ] {91959a95-0e26-4da0-818f-e13cc4503b0d} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument for function dateTrunc: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), date_trunc('minute', N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:37.396232 [ 6194 ] {1c6ca0c3-ed82-4039-a8d8-6d57c502f371} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:37.397187 [ 6194 ] {1c6ca0c3-ed82-4039-a8d8-6d57c502f371} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toTime: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toTime(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:38.035127 [ 2854 ] {0e161e16-3d84-43be-bd3b-1deb394ee4b0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55414) (comment: 01160_table_dependencies.sh) (in query: drop database test_krdjlok0_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:38.036926 [ 2854 ] {0e161e16-3d84-43be-bd3b-1deb394ee4b0} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:02:38.119737 [ 6194 ] {89929330-f2f6-4521-9bea-ccf14517d8d5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: SELECT 'SELECT toRelativeQuarterNum(N, \'Asia/Istanbul\')';) 2025.03.31 19:02:38.120684 [ 6194 ] {89929330-f2f6-4521-9bea-ccf14517d8d5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:02:38.347092 [ 2856 ] {f9a82950-7e88-4390-9af7-459d81fa3dc8} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:41758) (comment: 01160_table_dependencies.sh) (in query: DROP DATABASE IF EXISTS test_krdjlok0 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:02:38.348802 [ 2856 ] {f9a82950-7e88-4390-9af7-459d81fa3dc8} DynamicQueryHandler: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:02:38.691679 [ 4240 ] {6de7e5fa-6c0b-4d3f-a887-25fdfdc640ce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): while reading column c0 at /var/lib/clickhouse/store/49e/49eb9b29-e32c-4511-81f3-ba8d0a03ce8b/: While executing Log. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51786) (comment: 02766_bitshift_with_const_arguments.sql) (in query: SELECT ref_5.pkey AS c_2_c2392_6 FROM t0 AS ref_5 WHERE 'J[' < multiIf(ref_5.pkey IN ( SELECT 1 ), bitShiftLeft(multiIf(ref_5.c0 > NULL, '1', ')'), 40), 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003074f71a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003074ef60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003074b4d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x0000000030729b4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003072ac6f 11. DB::ReadBuffer::next() @ 0x00000000095afaaf 12. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x00000000206de5fa 13. DB::ReadBuffer::next() @ 0x00000000095afaaf 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320d5913 15. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x00000000320d51c2 16. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x00000000320d57ad 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032783be7 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 @ 0x00000000326328f0 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>>>&) @ 0x0000000038d451d0 20. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::LogSource::generate() @ 0x0000000038d42f3d 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae2c8d3 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 27. ./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*) @ 0x000000003ae9f89d 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:02:38.694625 [ 4240 ] {6de7e5fa-6c0b-4d3f-a887-25fdfdc640ce} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): while reading column c0 at /var/lib/clickhouse/store/49e/49eb9b29-e32c-4511-81f3-ba8d0a03ce8b/: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003074f71a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003074ef60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003074b4d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x0000000030729b4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003072ac6f 11. DB::ReadBuffer::next() @ 0x00000000095afaaf 12. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x00000000206de5fa 13. DB::ReadBuffer::next() @ 0x00000000095afaaf 14. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320d5913 15. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x00000000320d51c2 16. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:0: non-virtual thunk to DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x00000000320d57ad 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032783be7 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 @ 0x00000000326328f0 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>>>&) @ 0x0000000038d451d0 20. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::LogSource::generate() @ 0x0000000038d42f3d 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae2c8d3 22. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 27. ./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*) @ 0x000000003ae9f89d 28. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:02:38.780184 [ 2856 ] {37010882-e1ae-417f-bfbd-d86f3b6d85e7} 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.10457.altinitytest (altinity build)) (from [::1]:41768) (comment: 02766_bitshift_with_const_arguments.sql) (in query: DROP DATABASE IF EXISTS test_llwzynx1 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:02:38.782031 [ 2856 ] {37010882-e1ae-417f-bfbd-d86f3b6d85e7} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:02:40.044164 [ 3831 ] {e9a8bb7f-eefc-4165-8b73-6a1c53358b46} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52208) (comment: 01417_freeze_partition_verbose.sh) (in query: DROP DATABASE IF EXISTS test_uzwwosgo ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:02:40.045941 [ 3831 ] {e9a8bb7f-eefc-4165-8b73-6a1c53358b46} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:02:40.478724 [ 4187 ] {b8e18dee-fc34-48d2-8c1f-8cbc8a913430} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56402) (comment: 02868_select_support_from_keywords.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:02:40.480316 [ 4187 ] {b8e18dee-fc34-48d2-8c1f-8cbc8a913430} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:02:40.571691 [ 6107 ] {29810937-0ce4-4203-bc9a-43c1db3c1079} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57954) (comment: 02868_select_support_from_keywords.sql) (in query: DROP DATABASE IF EXISTS test_oijcn0yt ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:02:40.573341 [ 6107 ] {29810937-0ce4-4203-bc9a-43c1db3c1079} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:02:41.357058 [ 6194 ] {3553e15e-4e2d-4f4a-a827-8e031b937ff7} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:41.358091 [ 6194 ] {3553e15e-4e2d-4f4a-a827-8e031b937ff7} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:41.394822 [ 6194 ] {4b3d88d9-32fb-44d4-b3a8-4d8aa5b5ec44} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:41.395826 [ 6194 ] {4b3d88d9-32fb-44d4-b3a8-4d8aa5b5ec44} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:41.411474 [ 4187 ] {c0d1780f-6f35-4521-8e73-653a34d0b835} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56406) (comment: 00800_versatile_storage_join.sql) (in query: SELECT * from join_all_inner ORDER BY k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:02:41.414487 [ 4187 ] {c0d1780f-6f35-4521-8e73-653a34d0b835} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:02:41.437219 [ 6194 ] {2d850ad0-8e4e-4cec-b17a-256f1e32bfd1} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:41.438387 [ 6194 ] {2d850ad0-8e4e-4cec-b17a-256f1e32bfd1} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:41.515033 [ 6194 ] {d423a92d-cfdd-48e3-98a8-a73bc6c63f2f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: SELECT 'SELECT toYearWeek(N, \'Asia/Istanbul\')';) 2025.03.31 19:02:41.516018 [ 6194 ] {d423a92d-cfdd-48e3-98a8-a73bc6c63f2f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=726). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:02:41.554934 [ 6194 ] {f0d152bd-8e78-4d13-b5ee-e826d4ebb3d1} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:41.557250 [ 6194 ] {f0d152bd-8e78-4d13-b5ee-e826d4ebb3d1} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:41.597025 [ 6194 ] {0276f496-9b20-4e1f-a269-ab835aff1051} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:41.598099 [ 6194 ] {0276f496-9b20-4e1f-a269-ab835aff1051} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:41.634206 [ 6194 ] {1419a270-2c9e-4efa-a928-0fb22e7a83dc} executeQuery: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:41.635082 [ 6194 ] {1419a270-2c9e-4efa-a928-0fb22e7a83dc} TCPHandler: Code: 43. DB::Exception: Illegal type String of 2nd (optional) argument of function toYearWeek. Must be constant UInt8 (week mode).: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toYearWeek(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:41.670364 [ 6194 ] {c94f7380-16fe-48d8-b0f3-f34bd3f8e268} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: SELECT '------------------------------------------';) 2025.03.31 19:02:41.671361 [ 6194 ] {c94f7380-16fe-48d8-b0f3-f34bd3f8e268} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=726). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:02:41.757591 [ 6194 ] {fd087792-fa53-4091-b471-27650dbb2d2b} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function timeSlot: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:41.758794 [ 6194 ] {fd087792-fa53-4091-b471-27650dbb2d2b} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function timeSlot: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), timeSlot(N, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:43.315783 [ 6194 ] {18ad515a-55b8-4fe5-b961-0a9a531b1d64} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:43.316762 [ 6194 ] {18ad515a-55b8-4fe5-b961-0a9a531b1d64} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:43.595180 [ 6194 ] {283525e8-26d6-40e6-8ab3-72215f273396} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:43.600109 [ 6194 ] {283525e8-26d6-40e6-8ab3-72215f273396} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:44.016140 [ 6194 ] {3962b393-1a63-49c9-9aff-8a11f632a261} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:44.018299 [ 6194 ] {3962b393-1a63-49c9-9aff-8a11f632a261} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:44.458482 [ 6194 ] {7f3431ec-6e22-46b8-8eca-740f86fad412} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:44.459397 [ 6194 ] {7f3431ec-6e22-46b8-8eca-740f86fad412} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:44.734272 [ 6194 ] {36f3559e-5995-4c54-9aa7-1e228683fed8} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:44.735082 [ 6194 ] {36f3559e-5995-4c54-9aa7-1e228683fed8} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:44.946418 [ 6194 ] {d18b0f23-2f5a-4480-a2be-8c673e34dbe7} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:44.947372 [ 6194 ] {d18b0f23-2f5a-4480-a2be-8c673e34dbe7} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:45.278628 [ 6194 ] {1c94de92-e1ba-49cb-8a3b-4a9d17c746f7} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:45.279670 [ 6194 ] {1c94de92-e1ba-49cb-8a3b-4a9d17c746f7} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:45.536913 [ 6194 ] {9f8725b5-7094-4cbe-80b3-b7f712a2b714} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:45.537914 [ 6194 ] {9f8725b5-7094-4cbe-80b3-b7f712a2b714} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function addQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), addQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:45.864741 [ 6194 ] {04449780-eb20-4a39-bc2a-1e5e9961b981} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:45.866146 [ 6194 ] {04449780-eb20-4a39-bc2a-1e5e9961b981} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractYears. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractYears(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:46.065528 [ 6194 ] {d3caee48-7091-4d7d-b09d-2edbee694283} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:46.066407 [ 6194 ] {d3caee48-7091-4d7d-b09d-2edbee694283} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMonths. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMonths(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:46.358728 [ 6194 ] {227650bd-8bb3-4f0a-afe1-3e5291ece7ac} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:46.359621 [ 6194 ] {227650bd-8bb3-4f0a-afe1-3e5291ece7ac} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractWeeks. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractWeeks(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:46.602833 [ 6194 ] {5d6a5a8b-f6dc-469a-a38a-25477e559e30} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:46.603647 [ 6194 ] {5d6a5a8b-f6dc-469a-a38a-25477e559e30} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractDays. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractDays(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:46.807679 [ 6194 ] {6eb53fc4-eb7a-445f-84f9-56de77deeae0} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:46.808573 [ 6194 ] {6eb53fc4-eb7a-445f-84f9-56de77deeae0} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractHours. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:46.958907 [ 6194 ] {a1ee8574-a62a-4a77-93f7-536b372491f9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), subtractHours(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:46.959964 [ 6194 ] {a1ee8574-a62a-4a77-93f7-536b372491f9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=726). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:02:47.152960 [ 6194 ] {ba319454-e3d0-4987-987c-b9e4e513e8a0} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:47.154027 [ 6194 ] {ba319454-e3d0-4987-987c-b9e4e513e8a0} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractMinutes. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractMinutes(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:47.483849 [ 6194 ] {3c561d6d-69df-4018-a52c-a844ab250e9e} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:47.484786 [ 6194 ] {3c561d6d-69df-4018-a52c-a844ab250e9e} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractSeconds. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractSeconds(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:47.725533 [ 6194 ] {1fdc8fe8-1c97-4d23-b3db-088bfb24c203} executeQuery: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') as r FORMAT CSV;) 2025.03.31 19:02:47.726939 [ 6194 ] {1fdc8fe8-1c97-4d23-b3db-088bfb24c203} TCPHandler: Code: 43. DB::Exception: Illegal type Date of first argument of function subtractQuarters. Must be a DateTime/DateTime64: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), subtractQuarters(N, 1, 'Asia/Istanbul') AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:50.870899 [ 6194 ] {48957b60-a857-4914-931b-99af91d2103d} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N - N as r FORMAT CSV;) 2025.03.31 19:02:50.871813 [ 6194 ] {48957b60-a857-4914-931b-99af91d2103d} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:51.202816 [ 6194 ] {6d729150-90d1-4d5d-ae31-407b7cc868b7} executeQuery: Code: 43. DB::Exception: Illegal types Date and Date of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.03.31 19:02:51.203668 [ 6194 ] {6d729150-90d1-4d5d-ae31-407b7cc868b7} TCPHandler: Code: 43. DB::Exception: Illegal types Date and Date of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:51.315419 [ 6194 ] {fd012a33-50d9-4f0b-9807-776d9fadede2} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.03.31 19:02:51.316360 [ 6194 ] {fd012a33-50d9-4f0b-9807-776d9fadede2} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:51.350084 [ 6194 ] {e7cc6e3d-fe7c-469c-bc9f-4beb02c0477c} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N + N as r FORMAT CSV;) 2025.03.31 19:02:51.350984 [ 6194 ] {e7cc6e3d-fe7c-469c-bc9f-4beb02c0477c} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function plus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N + N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:53.088548 [ 2856 ] {cbaef845-ca81-4210-9019-630f05d97374} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38306) (comment: 01715_background_checker_blather_zookeeper_long.sql) (in query: DROP DATABASE IF EXISTS test_w3smxds7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:02:53.090599 [ 2856 ] {cbaef845-ca81-4210-9019-630f05d97374} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:02:53.854922 [ 6194 ] {292a7b98-2fb0-479b-be3d-33f412bc0607} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N - DT as r FORMAT CSV;) 2025.03.31 19:02:53.855842 [ 6194 ] {292a7b98-2fb0-479b-be3d-33f412bc0607} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:53.932774 [ 6194 ] {89913856-4eeb-4566-a15a-d35300436538} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - DT AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N - DT as r FORMAT CSV;) 2025.03.31 19:02:53.933593 [ 6194 ] {89913856-4eeb-4566-a15a-d35300436538} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - DT AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:53.963415 [ 3421 ] {} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339b83d8 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339b942e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339da35f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 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*) @ 0x00000000319a464f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:02:54.038151 [ 6194 ] {3b554fd2-e9eb-479a-8751-4af00b5e7907} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), DT - N as r FORMAT CSV;) 2025.03.31 19:02:54.039355 [ 6194 ] {3b554fd2-e9eb-479a-8751-4af00b5e7907} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:54.117258 [ 6194 ] {1801bbd4-8f4e-4e38-91ff-3d4095b68b06} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), DT - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), DT - N as r FORMAT CSV;) 2025.03.31 19:02:54.118404 [ 6194 ] {1801bbd4-8f4e-4e38-91ff-3d4095b68b06} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), DT - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:54.522951 [ 6194 ] {a636403c-ad1f-4855-b19a-5efbb5d6a8f0} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), N - D as r FORMAT CSV;) 2025.03.31 19:02:54.523832 [ 6194 ] {a636403c-ad1f-4855-b19a-5efbb5d6a8f0} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:54.558570 [ 6194 ] {5692e354-b592-4e3e-9531-cbe1ae2c1cfa} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N - D as r FORMAT CSV;) 2025.03.31 19:02:54.559338 [ 6194 ] {5692e354-b592-4e3e-9531-cbe1ae2c1cfa} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - D AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:54.730467 [ 6194 ] {a205bec4-39ff-438c-b07e-7b86212529a3} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), D - N as r FORMAT CSV;) 2025.03.31 19:02:54.731262 [ 6194 ] {a205bec4-39ff-438c-b07e-7b86212529a3} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:54.861829 [ 6194 ] {328fd46d-25f8-4ece-9436-b44313e46320} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), D - N as r FORMAT CSV;) 2025.03.31 19:02:54.862749 [ 6194 ] {328fd46d-25f8-4ece-9436-b44313e46320} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), D - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:55.047815 [ 6194 ] {8a202f6c-b84a-4df2-a57d-45f02625d856} executeQuery: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N - DT64 as r FORMAT CSV;) 2025.03.31 19:02:55.048669 [ 6194 ] {8a202f6c-b84a-4df2-a57d-45f02625d856} TCPHandler: Code: 43. DB::Exception: Illegal types Date and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:55.082552 [ 6194 ] {56199bf9-724e-4966-982e-70b76530fc8e} executeQuery: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), N - DT64 as r FORMAT CSV;) 2025.03.31 19:02:55.083535 [ 6194 ] {56199bf9-724e-4966-982e-70b76530fc8e} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime('Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:55.114899 [ 6194 ] {929b61a1-cc87-47ff-bac6-3e804ed53dc2} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N - DT64 as r FORMAT CSV;) 2025.03.31 19:02:55.115738 [ 6194 ] {929b61a1-cc87-47ff-bac6-3e804ed53dc2} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), N - DT64 AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:55.268496 [ 6194 ] {048f964d-4bf3-4b1a-8198-aa94831356e4} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), DT64 - N as r FORMAT CSV;) 2025.03.31 19:02:55.269642 [ 6194 ] {048f964d-4bf3-4b1a-8198-aa94831356e4} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and Date of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:55.314174 [ 2856 ] {1eac89ad-53bd-4c8c-94ff-ea158cbd9cdd} executeQuery: Code: 190. DB::Exception: Elements 'NestedColumn.ID' and 'NestedColumn.Count' of Nested data structure 'NestedColumn' (Array columns) have different array sizes. (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:49552) (comment: 00698_validate_array_sizes_for_nested_kshvakov.sql) (in query: INSERT INTO Issue_2231_Invalid_Nested_Columns_Size 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&) @ 0x0000000032579157 4. ./build_docker/./src/DataTypes/NestedUtils.cpp:261: DB::Nested::validateArraySizes(DB::Block const&) @ 0x0000000032572747 5. ./src/Core/Block.h:25: DB::NestedElementsValidationTransform::transform(DB::Chunk&) @ 0x000000003b89b000 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aeae699 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abb4eaa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:02:55.315414 [ 2856 ] {1eac89ad-53bd-4c8c-94ff-ea158cbd9cdd} TCPHandler: Code: 190. DB::Exception: Elements 'NestedColumn.ID' and 'NestedColumn.Count' of Nested data structure 'NestedColumn' (Array columns) have different array sizes. (SIZES_OF_ARRAYS_DONT_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String const&, String&) @ 0x0000000032579157 4. ./build_docker/./src/DataTypes/NestedUtils.cpp:261: DB::Nested::validateArraySizes(DB::Block const&) @ 0x0000000032572747 5. ./src/Core/Block.h:25: DB::NestedElementsValidationTransform::transform(DB::Chunk&) @ 0x000000003b89b000 6. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 7. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 11. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:123: DB::PushingPipelineExecutor::finish() @ 0x000000003aeae699 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000003abb4eaa 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f16 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:02:55.445184 [ 6194 ] {e65bfa77-c50c-45a9-ac72-fe71343dc3f6} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), DT64 - N as r FORMAT CSV;) 2025.03.31 19:02:55.446265 [ 6194 ] {e65bfa77-c50c-45a9-ac72-fe71343dc3f6} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime('Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:55.477531 [ 6194 ] {31a95e15-025c-4f62-8ded-18480d5547cb} executeQuery: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), DT64 - N as r FORMAT CSV;) 2025.03.31 19:02:55.478503 [ 6194 ] {31a95e15-025c-4f62-8ded-18480d5547cb} TCPHandler: Code: 43. DB::Exception: Illegal types DateTime64(3, 'Europe/Minsk') and DateTime64(3, 'Europe/Minsk') of arguments of function minus: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), DT64 - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:02:55.591923 [ 6194 ] {0545ca81-0a46-4ae8-b638-520bdead9180} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != DT as r FORMAT CSV;) 2025.03.31 19:02:55.592782 [ 6194 ] {0545ca81-0a46-4ae8-b638-520bdead9180} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:02:56.062982 [ 3830 ] {64308c10-4782-4746-8c75-9a4f6e017734} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:49564) (comment: 02269_to_start_of_interval_overflow.sql) (in query: select toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000001c7001fc 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6fc03b 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6f7ec4 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000001c6f72e4 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c6f5e27 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:02:56.064062 [ 3830 ] {64308c10-4782-4746-8c75-9a4f6e017734} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000001c7001fc 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6fc03b 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6f7ec4 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000001c6f72e4 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c6f5e27 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:02:56.093658 [ 3830 ] {154343f9-8aa2-42ac-b806-caa13e3db5f6} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:49564) (comment: 02269_to_start_of_interval_overflow.sql) (in query: SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000001c7001fc 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6fc03b 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6f7ec4 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000001c6f72e4 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c6f5e27 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:02:56.094751 [ 3830 ] {154343f9-8aa2-42ac-b806-caa13e3db5f6} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT toDateTime64(-9223372036854775808, 1048575, toIntervalNanosecond(9223372036854775806), NULL), toStartOfInterval(toDateTime64(toIntervalNanosecond(toIntervalNanosecond(257), toDateTime64(toStartOfInterval(toDateTime64(NULL)))), '', 100), toIntervalNanosecond(toStartOfInterval(toDateTime64(toIntervalNanosecond(NULL), NULL)), -1)), toStartOfInterval(toDateTime64('\0930-12-12 12:12:12.1234567', 3), toIntervalNanosecond(1024)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. DB::ToStartOfInterval<(DB::IntervalKind::Kind)0>::execute(long, long, DateLUTImpl const&, long) @ 0x000000001c7001fc 5. COW::immutable_ptr DB::FunctionToStartOfInterval::execute, DB::DataTypeDateTime64, (DB::IntervalKind::Kind)0>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, long, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6fc03b 6. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime64 const&, DB::ColumnDecimal const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x000000001c6f7ec4 7. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x000000001c6f72e4 8. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c6f5e27 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:02:56.105981 [ 6194 ] {7bd8406c-e8da-4006-9767-8090c15776cc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), DT != N as r FORMAT CSV;) 2025.03.31 19:02:56.106925 [ 6194 ] {7bd8406c-e8da-4006-9767-8090c15776cc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:02:57.753608 [ 6194 ] {e01dd657-de2b-4ac7-be5f-7d8de8a3a56c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), N == DT as r FORMAT CSV;) 2025.03.31 19:02:57.754781 [ 6194 ] {e01dd657-de2b-4ac7-be5f-7d8de8a3a56c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:03:04.400959 [ 3830 ] {5fc5e9b6-c3f9-4ef0-815d-b6cda403b1c7} executeQuery: Code: 57. DB::Exception: Table test_axih3t3t.csv already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45580) (comment: 00301_csv.sh) (in query: CREATE TABLE csv (t DateTime('Asia/Istanbul'), s 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:04.402880 [ 3830 ] {5fc5e9b6-c3f9-4ef0-815d-b6cda403b1c7} TCPHandler: Code: 57. DB::Exception: Table test_axih3t3t.csv 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:05.336826 [ 2856 ] {419a847b-76c6-4077-a335-b245c8af1aed} executeQuery: Code: 43. DB::Exception: Elements of array of second argument of function roundDown must be numeric type.: In scope SELECT 1 AS x, roundDown(x, []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45566) (comment: 00805_round_down.sql) (in query: SELECT 1 as x, roundDown(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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::FunctionRoundDown::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b3e3aa8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:03:05.337839 [ 2856 ] {419a847b-76c6-4077-a335-b245c8af1aed} TCPHandler: Code: 43. DB::Exception: Elements of array of second argument of function roundDown must be numeric type.: In scope SELECT 1 AS x, roundDown(x, []). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::FunctionRoundDown::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b3e3aa8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:03:06.675550 [ 2856 ] {065c0df4-4ac4-435c-bf12-30f9739363a7} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45566) (comment: 00805_round_down.sql) (in query: SELECT 1 as x, roundDown(x, emptyArrayUInt8());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fa700 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003323df50 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000332390a3 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b7e6eb7 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdba655 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d144de 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfd32c 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 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*) @ 0x000000003589fd91 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:03:06.676829 [ 2856 ] {065c0df4-4ac4-435c-bf12-30f9739363a7} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fa700 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003323df50 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000332390a3 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b7e6eb7 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdba655 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d144de 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfd32c 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 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*) @ 0x000000003589fd91 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:03:06.763818 [ 2856 ] {8a4418ad-c7db-4949-8d63-7178dd81c375} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (ILLEGAL_COLUMN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45566) (comment: 00805_round_down.sql) (in query: SELECT roundDown(number, [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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fa700 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003323df50 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000332390a3 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b7e6eb7 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdba655 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d144de 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfd32c 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 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*) @ 0x000000003589fd91 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:03:06.764888 [ 2856 ] {8a4418ad-c7db-4949-8d63-7178dd81c375} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function roundDown must be constant. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fa700 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 8. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003323df50 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000332390a3 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000003b7e6eb7 11. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000003bdba655 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000034d144de 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfd32c 14. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 15. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 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*) @ 0x000000003589fd91 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:03:09.159631 [ 6194 ] {a21b3947-8a43-4014-9f65-77cf743ac7a3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: SELECT 'SELECT toUInt16(1) + N';) 2025.03.31 19:03:09.160579 [ 6194 ] {a21b3947-8a43-4014-9f65-77cf743ac7a3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:03:10.134512 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:10.225091 [ 5920 ] {} test_un0nmf79.test_rewrite_uniq_to_count (8b5321cd-e893-446e-b5ed-797a558255bd): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.03.31 19:03:10.225614 [ 5920 ] {} DatabaseCatalog: Cannot drop table test_un0nmf79.test_rewrite_uniq_to_count (8b5321cd-e893-446e-b5ed-797a558255bd). Will retry later.: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 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>*) @ 0x00000000397276a1 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>*) @ 0x0000000039720472 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2997: DB::MergeTreeData::dropAllData() @ 0x0000000039736baa 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2cda53 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339b9fe2 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339daaa3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303ec68c 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()() @ 0x00000000303ec46d 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b123d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303eeb6e 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:03:10.417980 [ 2854 ] {dc13a11c-dab0-4baf-a4de-f24cfc0197f6} executeQuery: Code: 57. DB::Exception: Table test_axih3t3t.csv already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47148) (comment: 00301_csv.sh) (in query: CREATE TABLE csv (s String, n UInt64 DEFAULT 3, d String DEFAULT 'String4') 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:10.419656 [ 2854 ] {dc13a11c-dab0-4baf-a4de-f24cfc0197f6} TCPHandler: Code: 57. DB::Exception: Table test_axih3t3t.csv 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:11.128778 [ 6194 ] {1cfb5d34-c7cc-4cce-840f-100dd64e8dfd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: SELECT '------------------------------------------';) 2025.03.31 19:03:11.129660 [ 6194 ] {1cfb5d34-c7cc-4cce-840f-100dd64e8dfd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:03:12.586869 [ 6194 ] {7f868bd2-44ca-4306-a547-a7f914cefa03} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.03.31 19:03:12.587930 [ 6194 ] {7f868bd2-44ca-4306-a547-a7f914cefa03} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:12.718923 [ 6194 ] {7b9637a8-90bd-4fa5-94e8-f3e9c85cdc2e} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.03.31 19:03:12.719805 [ 6194 ] {7b9637a8-90bd-4fa5-94e8-f3e9c85cdc2e} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:12.752162 [ 6194 ] {f21a0b91-619f-4c71-9e62-fc847e532692} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt8(1) - N as r FORMAT CSV;) 2025.03.31 19:03:12.753027 [ 6194 ] {f21a0b91-619f-4c71-9e62-fc847e532692} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt8(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:13.366837 [ 6194 ] {dab04ce8-e59b-47ac-a5e5-57e46aaf8262} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:13.367800 [ 6194 ] {dab04ce8-e59b-47ac-a5e5-57e46aaf8262} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:13.394654 [ 6194 ] {630dc5d1-da41-484e-8a2d-3ccb42f5d788} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:13.395418 [ 6194 ] {630dc5d1-da41-484e-8a2d-3ccb42f5d788} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:13.424009 [ 6194 ] {7dd94d75-3192-430f-b264-8c7a63979e7e} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt8(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:13.424870 [ 6194 ] {7dd94d75-3192-430f-b264-8c7a63979e7e} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt8(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:13.464725 [ 2854 ] {9303033c-dd69-4c06-9f87-938e2fd5f137} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'n' in scope SELECT * FROM csv ORDER BY s ASC, n ASC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47172) (comment: 00301_csv.sh) (in query: SELECT * FROM csv ORDER BY s, n), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334cc379 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033428e24 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:03:13.466407 [ 2854 ] {9303033c-dd69-4c06-9f87-938e2fd5f137} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'n' in scope SELECT * FROM csv ORDER BY s ASC, n ASC. Maybe you meant: ['t']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334cc379 6. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033428e24 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:03:14.036146 [ 6194 ] {ec4d8a9f-91d6-426f-98c8-cfbbae646bf4} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.03.31 19:03:14.037040 [ 6194 ] {ec4d8a9f-91d6-426f-98c8-cfbbae646bf4} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:14.070949 [ 6194 ] {64efb78e-0192-4d69-acb1-49c3a7392f5b} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.03.31 19:03:14.071976 [ 6194 ] {64efb78e-0192-4d69-acb1-49c3a7392f5b} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:14.102111 [ 6194 ] {ea1376c4-0a39-4ca6-815e-1a37beed8f04} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt16(1) - N as r FORMAT CSV;) 2025.03.31 19:03:14.103154 [ 6194 ] {ea1376c4-0a39-4ca6-815e-1a37beed8f04} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt16(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:14.622332 [ 6194 ] {6fa78c98-2324-4c5b-9f9b-8af84ab3b3ce} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:14.623389 [ 6194 ] {6fa78c98-2324-4c5b-9f9b-8af84ab3b3ce} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:14.702367 [ 6194 ] {b3df5e90-a60f-42ad-87f7-b51434882f05} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:14.703167 [ 6194 ] {b3df5e90-a60f-42ad-87f7-b51434882f05} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:14.729205 [ 6194 ] {1df2fdf5-87e9-495d-a498-733983f2587c} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt16(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:14.730617 [ 6194 ] {1df2fdf5-87e9-495d-a498-733983f2587c} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt16(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:15.006459 [ 6194 ] {99dcef26-d508-42d9-91bb-e3ea83fddf63} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.03.31 19:03:15.007463 [ 6194 ] {99dcef26-d508-42d9-91bb-e3ea83fddf63} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:15.034798 [ 6194 ] {c0b49cf4-61ed-4178-acf7-0e8fa0d2d402} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.03.31 19:03:15.035652 [ 6194 ] {c0b49cf4-61ed-4178-acf7-0e8fa0d2d402} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:15.061158 [ 6194 ] {106d67aa-77e1-4ab1-80e1-e04a67a55655} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt32(1) - N as r FORMAT CSV;) 2025.03.31 19:03:15.062201 [ 6194 ] {106d67aa-77e1-4ab1-80e1-e04a67a55655} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt32(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:15.505269 [ 6194 ] {2edcbe19-ccf2-412c-89ba-974bcdff28a5} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:15.506256 [ 6194 ] {2edcbe19-ccf2-412c-89ba-974bcdff28a5} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:15.532526 [ 6194 ] {88631684-3109-456e-8ffe-d1176c97201b} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:15.533330 [ 6194 ] {88631684-3109-456e-8ffe-d1176c97201b} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:15.563066 [ 6194 ] {4ad85165-e8e6-44ac-bb13-01317c38a150} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt32(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:15.563950 [ 6194 ] {4ad85165-e8e6-44ac-bb13-01317c38a150} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt32(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:16.159160 [ 6194 ] {6869dd2b-6932-4b03-91dc-8cb68533a616} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.03.31 19:03:16.160183 [ 6194 ] {6869dd2b-6932-4b03-91dc-8cb68533a616} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:16.189199 [ 6194 ] {74d0d6a5-7d15-4ef1-a199-a358f5f1585e} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.03.31 19:03:16.190566 [ 6194 ] {74d0d6a5-7d15-4ef1-a199-a358f5f1585e} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:16.290950 [ 6194 ] {8898f407-8392-4a0c-b1c6-69e37637a875} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toUInt64(1) - N as r FORMAT CSV;) 2025.03.31 19:03:16.291844 [ 6194 ] {8898f407-8392-4a0c-b1c6-69e37637a875} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toUInt64(1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:16.689116 [ 6194 ] {57eab335-44a2-4a15-a0fd-8a4bdc5983b8} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:16.716065 [ 6194 ] {57eab335-44a2-4a15-a0fd-8a4bdc5983b8} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:16.744503 [ 6194 ] {1c6bb6e8-84fa-45ac-8a8f-5bb880fd6ffc} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:16.745571 [ 6194 ] {1c6bb6e8-84fa-45ac-8a8f-5bb880fd6ffc} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:16.775964 [ 6194 ] {7a7ff42a-8c69-4b59-8350-d921fc54aaed} executeQuery: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), toInt64(-1) - N as r FORMAT CSV;) 2025.03.31 19:03:16.776928 [ 6194 ] {7a7ff42a-8c69-4b59-8350-d921fc54aaed} TCPHandler: Code: 43. DB::Exception: Wrong order of arguments for function minus: argument of type Interval cannot be first: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, DT64 AS N SELECT toTypeName(r), toInt64(-1) - N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:16.997296 [ 6194 ] {fed203c3-dcb8-4483-9ecd-42122b025268} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt8(1) as r FORMAT CSV;) 2025.03.31 19:03:16.998656 [ 6194 ] {fed203c3-dcb8-4483-9ecd-42122b025268} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:17.261165 [ 6194 ] {d276d7f2-e064-4513-9afe-8f94f2a97621} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) == N as r FORMAT CSV;) 2025.03.31 19:03:17.262193 [ 6194 ] {d276d7f2-e064-4513-9afe-8f94f2a97621} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:17.453515 [ 6194 ] {ca887655-2361-43e4-9912-ae6afa5fd8ba} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: SELECT '------------------------------------------';) 2025.03.31 19:03:17.469520 [ 6194 ] {ca887655-2361-43e4-9912-ae6afa5fd8ba} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:03:17.600738 [ 6194 ] {b9cf1b3a-42ea-429a-b115-6bbe0dc8c37f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt8(-1) as r FORMAT CSV;) 2025.03.31 19:03:17.601741 [ 6194 ] {b9cf1b3a-42ea-429a-b115-6bbe0dc8c37f} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:17.916512 [ 6194 ] {88c51f67-2eec-4280-bd39-a040de36602e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) == N as r FORMAT CSV;) 2025.03.31 19:03:17.917383 [ 6194 ] {88c51f67-2eec-4280-bd39-a040de36602e} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:18.088655 [ 6194 ] {0f32466e-ea5f-4b5b-aab4-20eafbbe11ea} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt16(1) as r FORMAT CSV;) 2025.03.31 19:03:18.089973 [ 6194 ] {0f32466e-ea5f-4b5b-aab4-20eafbbe11ea} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:18.359952 [ 6194 ] {fef3b873-9d9e-486c-b874-f916899825ce} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) == N as r FORMAT CSV;) 2025.03.31 19:03:18.361138 [ 6194 ] {fef3b873-9d9e-486c-b874-f916899825ce} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:18.860316 [ 6194 ] {08efc01a-1d95-4e2a-a967-457dd824527e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt16(-1) as r FORMAT CSV;) 2025.03.31 19:03:18.861380 [ 6194 ] {08efc01a-1d95-4e2a-a967-457dd824527e} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:19.054625 [ 6194 ] {68eb795a-1cff-40fa-a372-e6c8705d78ca} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) == N as r FORMAT CSV;) 2025.03.31 19:03:19.055603 [ 6194 ] {68eb795a-1cff-40fa-a372-e6c8705d78ca} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:19.375801 [ 6194 ] {a2230b75-221a-4158-ba5b-1fd7675448b0} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt32(1) as r FORMAT CSV;) 2025.03.31 19:03:19.376779 [ 6194 ] {a2230b75-221a-4158-ba5b-1fd7675448b0} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:19.767981 [ 6194 ] {04ef686b-f78e-440d-9d31-ab3e2fd6257e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) == N as r FORMAT CSV;) 2025.03.31 19:03:19.768907 [ 6194 ] {04ef686b-f78e-440d-9d31-ab3e2fd6257e} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:20.012309 [ 6194 ] {993915a1-d6d8-4b31-973b-716476dd9c8a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt32(-1) as r FORMAT CSV;) 2025.03.31 19:03:20.013492 [ 6194 ] {993915a1-d6d8-4b31-973b-716476dd9c8a} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:20.268260 [ 6194 ] {3d2976c2-39be-4550-97e1-55f328479997} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) == N as r FORMAT CSV;) 2025.03.31 19:03:20.269220 [ 6194 ] {3d2976c2-39be-4550-97e1-55f328479997} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:20.617011 [ 6194 ] {ea888947-e5fc-4d36-90f7-4849d3d331c9} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toUInt64(1) as r FORMAT CSV;) 2025.03.31 19:03:20.643775 [ 6194 ] {ea888947-e5fc-4d36-90f7-4849d3d331c9} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:20.931615 [ 6194 ] {7cc849e5-1b19-4018-b162-4ff5962ab000} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) == N as r FORMAT CSV;) 2025.03.31 19:03:20.932547 [ 6194 ] {7cc849e5-1b19-4018-b162-4ff5962ab000} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:21.407630 [ 6194 ] {1f932f1f-690d-4425-ab17-b9149abba63a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N == toInt64(-1) as r FORMAT CSV;) 2025.03.31 19:03:21.408653 [ 6194 ] {1f932f1f-690d-4425-ab17-b9149abba63a} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N = toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:21.547190 [ 3830 ] {00cf1e13-0a4a-4112-b8e0-3f6029bc544e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45194) (comment: 00982_low_cardinality_setting_in_mv.sql) (in query: CREATE TABLE test2 (`a` UInt64) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 40699, min_bytes_for_wide_part = 285259143, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 434594271, compact_parts_max_granules_to_buffer = 231, compact_parts_merge_max_bytes_to_prefetch_part = 4909552, merge_max_block_size = 4996, old_parts_lifetime = 28., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7332205, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 46008, primary_key_compress_block_size = 65168), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 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>) @ 0x000000003a2c1d8a 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>&&) @ 0x000000003a2bfe8f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:03:21.549098 [ 3830 ] {00cf1e13-0a4a-4112-b8e0-3f6029bc544e} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 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>) @ 0x000000003a2c1d8a 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>&&) @ 0x000000003a2bfe8f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:03:21.732193 [ 6194 ] {ddba859c-e248-49a2-a683-7c81d6d7f75d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) == N as r FORMAT CSV;) 2025.03.31 19:03:21.733427 [ 6194 ] {ddba859c-e248-49a2-a683-7c81d6d7f75d} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function equals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) = N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:22.015061 [ 6194 ] {27034c5b-a2eb-46ff-b6db-1e72ff5ce6d9} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt8(1) as r FORMAT CSV;) 2025.03.31 19:03:22.015926 [ 6194 ] {27034c5b-a2eb-46ff-b6db-1e72ff5ce6d9} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:22.189324 [ 6194 ] {24e8b820-43ea-4a3f-ad96-f9b2cc52d434} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) != N as r FORMAT CSV;) 2025.03.31 19:03:22.190344 [ 6194 ] {24e8b820-43ea-4a3f-ad96-f9b2cc52d434} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:22.508989 [ 6194 ] {55df2944-6834-4cd0-b801-198871f33f98} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt8(-1) as r FORMAT CSV;) 2025.03.31 19:03:22.510232 [ 6194 ] {55df2944-6834-4cd0-b801-198871f33f98} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:22.770872 [ 6194 ] {f549f22e-6a98-4967-b93e-91a3e3ba47f4} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) != N as r FORMAT CSV;) 2025.03.31 19:03:22.772093 [ 6194 ] {f549f22e-6a98-4967-b93e-91a3e3ba47f4} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:22.947324 [ 6194 ] {a6903c0b-ceff-4f92-bc52-6ebd179bf0b2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt16(1) as r FORMAT CSV;) 2025.03.31 19:03:22.948928 [ 6194 ] {a6903c0b-ceff-4f92-bc52-6ebd179bf0b2} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:23.153927 [ 6194 ] {53b1d7a7-b4aa-4cdf-9757-c64cd1b08329} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) != N as r FORMAT CSV;) 2025.03.31 19:03:23.154961 [ 6194 ] {53b1d7a7-b4aa-4cdf-9757-c64cd1b08329} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:23.451697 [ 6194 ] {b04ae575-df92-4763-9a14-64c31ded22c2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt16(-1) as r FORMAT CSV;) 2025.03.31 19:03:23.452590 [ 6194 ] {b04ae575-df92-4763-9a14-64c31ded22c2} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:23.680729 [ 6194 ] {20533b32-ebc4-4939-8720-ed6304e0daa8} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) != N as r FORMAT CSV;) 2025.03.31 19:03:23.681872 [ 6194 ] {20533b32-ebc4-4939-8720-ed6304e0daa8} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:23.926326 [ 6194 ] {86ac30b5-84ce-4f71-9a82-7ad4733ce08f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt32(1) as r FORMAT CSV;) 2025.03.31 19:03:23.927460 [ 6194 ] {86ac30b5-84ce-4f71-9a82-7ad4733ce08f} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:24.163907 [ 6194 ] {57fadffb-e50e-4157-81c0-1c73ce868894} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) != N as r FORMAT CSV;) 2025.03.31 19:03:24.164889 [ 6194 ] {57fadffb-e50e-4157-81c0-1c73ce868894} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:24.396934 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:24.510199 [ 6194 ] {b13923ca-b971-4067-b66b-dff0eb5691d6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt32(-1) as r FORMAT CSV;) 2025.03.31 19:03:24.521991 [ 6194 ] {b13923ca-b971-4067-b66b-dff0eb5691d6} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:24.900134 [ 6194 ] {04336934-46bc-4b8a-b505-60c101291180} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) != N as r FORMAT CSV;) 2025.03.31 19:03:24.900981 [ 6194 ] {04336934-46bc-4b8a-b505-60c101291180} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:25.058188 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:25.217842 [ 6194 ] {8d2115e1-b4db-4ac5-98c3-e13e677456e7} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toUInt64(1) as r FORMAT CSV;) 2025.03.31 19:03:25.219101 [ 6194 ] {8d2115e1-b4db-4ac5-98c3-e13e677456e7} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:25.529178 [ 6194 ] {8f5f934c-ee0b-450b-8cbb-1fba815b1981} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) != N as r FORMAT CSV;) 2025.03.31 19:03:25.530500 [ 6194 ] {8f5f934c-ee0b-450b-8cbb-1fba815b1981} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:25.867660 [ 6194 ] {08e1ad87-0779-48a8-b4d2-85e3a4178b82} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N != toInt64(-1) as r FORMAT CSV;) 2025.03.31 19:03:25.868933 [ 6194 ] {08e1ad87-0779-48a8-b4d2-85e3a4178b82} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N != toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:26.021480 [ 6194 ] {f9059b91-53dc-4291-867f-3bd29fcbf77d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N != toInt64(-1) as r FORMAT CSV;) 2025.03.31 19:03:26.023006 [ 6194 ] {f9059b91-53dc-4291-867f-3bd29fcbf77d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:03:26.109343 [ 6194 ] {c872e2d7-820f-4d0e-9a42-410e5fa21577} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) != N as r FORMAT CSV;) 2025.03.31 19:03:26.221963 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:26.261986 [ 6194 ] {c872e2d7-820f-4d0e-9a42-410e5fa21577} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function notEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) != N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:26.637272 [ 6194 ] {3b044342-e9b8-4c89-93d0-a0a37759c91a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt8(1) as r FORMAT CSV;) 2025.03.31 19:03:26.638272 [ 6194 ] {3b044342-e9b8-4c89-93d0-a0a37759c91a} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:26.985376 [ 6194 ] {46a08d94-c03b-497d-b915-36a368ac2daf} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) < N as r FORMAT CSV;) 2025.03.31 19:03:26.986696 [ 6194 ] {46a08d94-c03b-497d-b915-36a368ac2daf} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:27.350653 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:27.442906 [ 6194 ] {9498b257-1ca2-44b2-b7d2-bb748fadc386} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt8(-1) as r FORMAT CSV;) 2025.03.31 19:03:27.443739 [ 6194 ] {9498b257-1ca2-44b2-b7d2-bb748fadc386} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:27.708586 [ 6194 ] {35b8fa79-01b7-4cba-8f3c-6d3a2db3d371} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) < N as r FORMAT CSV;) 2025.03.31 19:03:27.709560 [ 6194 ] {35b8fa79-01b7-4cba-8f3c-6d3a2db3d371} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:27.978468 [ 6194 ] {9b6097c1-8d3f-4779-a4d4-64d01c0bf554} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt16(1) as r FORMAT CSV;) 2025.03.31 19:03:27.979291 [ 6194 ] {9b6097c1-8d3f-4779-a4d4-64d01c0bf554} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:28.332319 [ 6194 ] {1840dfd8-78f3-4583-892d-66bf5b113c3b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) < N as r FORMAT CSV;) 2025.03.31 19:03:28.333402 [ 6194 ] {1840dfd8-78f3-4583-892d-66bf5b113c3b} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:28.411300 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:28.897036 [ 6194 ] {3a42a9c9-d607-4467-bc77-e5e598872f66} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt16(-1) as r FORMAT CSV;) 2025.03.31 19:03:28.898061 [ 6194 ] {3a42a9c9-d607-4467-bc77-e5e598872f66} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:29.230434 [ 6194 ] {89a72d85-a338-48a2-aeb0-f9ecf7249cd6} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) < N as r FORMAT CSV;) 2025.03.31 19:03:29.231488 [ 6194 ] {89a72d85-a338-48a2-aeb0-f9ecf7249cd6} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:29.573373 [ 6194 ] {4bc66aa8-e909-4fb2-9a96-690f36b9db7c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt32(1) as r FORMAT CSV;) 2025.03.31 19:03:29.574632 [ 6194 ] {4bc66aa8-e909-4fb2-9a96-690f36b9db7c} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:29.633002 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:29.899938 [ 6194 ] {9e6b4820-e279-45a9-8051-cfe783c184a8} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) < N as r FORMAT CSV;) 2025.03.31 19:03:29.900922 [ 6194 ] {9e6b4820-e279-45a9-8051-cfe783c184a8} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:30.151695 [ 6194 ] {c7bd969c-c714-47e6-b39e-c60a58b3b3cc} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt32(-1) as r FORMAT CSV;) 2025.03.31 19:03:30.152599 [ 6194 ] {c7bd969c-c714-47e6-b39e-c60a58b3b3cc} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:30.498961 [ 6194 ] {b821d02e-e474-4385-88de-7eaaec8671de} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) < N as r FORMAT CSV;) 2025.03.31 19:03:30.499854 [ 6194 ] {b821d02e-e474-4385-88de-7eaaec8671de} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:30.727850 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:30.900709 [ 6194 ] {8a9c45c0-76cc-452d-85c1-d29596cac64f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toUInt64(1) as r FORMAT CSV;) 2025.03.31 19:03:30.901674 [ 6194 ] {8a9c45c0-76cc-452d-85c1-d29596cac64f} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:31.329410 [ 6194 ] {45e2755b-ca8b-417c-9ce5-0a88cd843037} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) < N as r FORMAT CSV;) 2025.03.31 19:03:31.330404 [ 6194 ] {45e2755b-ca8b-417c-9ce5-0a88cd843037} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:31.443049 [ 6194 ] {57eb94c0-2d4b-4bbf-844f-c5db8e81282e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: SELECT 'SELECT N < toInt64(-1)';) 2025.03.31 19:03:31.444477 [ 6194 ] {57eb94c0-2d4b-4bbf-844f-c5db8e81282e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:03:31.470211 [ 6194 ] {15799a92-2cd7-43a1-80f9-d36deb394fdc} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N < toInt64(-1) as r FORMAT CSV;) 2025.03.31 19:03:31.471100 [ 6194 ] {15799a92-2cd7-43a1-80f9-d36deb394fdc} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N < toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:31.812495 [ 6194 ] {594d16ed-167f-4cf7-bd97-83376d3d990f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) < N as r FORMAT CSV;) 2025.03.31 19:03:31.813377 [ 6194 ] {594d16ed-167f-4cf7-bd97-83376d3d990f} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function less: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) < N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:31.827990 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:32.057256 [ 6194 ] {af7507aa-8ab5-4bb8-b3d3-ec04470f5435} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: SELECT '------------------------------------------';) 2025.03.31 19:03:32.058265 [ 6194 ] {af7507aa-8ab5-4bb8-b3d3-ec04470f5435} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:03:32.108936 [ 6194 ] {8f96febd-2b6e-4a31-8d43-aab9e9e268fe} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt8(1) as r FORMAT CSV;) 2025.03.31 19:03:32.109893 [ 6194 ] {8f96febd-2b6e-4a31-8d43-aab9e9e268fe} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:32.330916 [ 6194 ] {9edda7cf-d62b-45c8-94c3-0cc16c3b540a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) <= N as r FORMAT CSV;) 2025.03.31 19:03:32.331847 [ 6194 ] {9edda7cf-d62b-45c8-94c3-0cc16c3b540a} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:32.565604 [ 6194 ] {c72f2801-7f58-47eb-9668-78978ccd79fa} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt8(-1) as r FORMAT CSV;) 2025.03.31 19:03:32.566736 [ 6194 ] {c72f2801-7f58-47eb-9668-78978ccd79fa} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:32.888472 [ 6194 ] {b46bf734-7df7-4666-99da-bf492dec9337} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) <= N as r FORMAT CSV;) 2025.03.31 19:03:32.889326 [ 6194 ] {b46bf734-7df7-4666-99da-bf492dec9337} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:32.989681 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:33.190493 [ 6194 ] {be4ab28e-3424-40fd-8c2c-4336906c1116} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt16(1) as r FORMAT CSV;) 2025.03.31 19:03:33.191379 [ 6194 ] {be4ab28e-3424-40fd-8c2c-4336906c1116} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:33.334774 [ 6194 ] {3322f9cb-cc6f-44c4-819e-8aed9eab76f0} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) <= N as r FORMAT CSV;) 2025.03.31 19:03:33.336097 [ 6194 ] {3322f9cb-cc6f-44c4-819e-8aed9eab76f0} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:33.497264 [ 6194 ] {d6205916-c0ba-4595-83a8-54b9d9065f79} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt16(-1) as r FORMAT CSV;) 2025.03.31 19:03:33.498404 [ 6194 ] {d6205916-c0ba-4595-83a8-54b9d9065f79} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:33.757043 [ 6194 ] {2049be5c-e57f-460f-bf3c-6ed8b5d73b29} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) <= N as r FORMAT CSV;) 2025.03.31 19:03:33.790650 [ 6194 ] {2049be5c-e57f-460f-bf3c-6ed8b5d73b29} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:34.029894 [ 6194 ] {95651e28-3589-4f99-a314-9c3883c92478} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt32(1) as r FORMAT CSV;) 2025.03.31 19:03:34.030898 [ 6194 ] {95651e28-3589-4f99-a314-9c3883c92478} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:34.103975 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:34.290372 [ 6194 ] {8905affa-cf51-4feb-8f55-8ce452ef480b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) <= N as r FORMAT CSV;) 2025.03.31 19:03:34.291259 [ 6194 ] {8905affa-cf51-4feb-8f55-8ce452ef480b} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:34.526464 [ 6194 ] {fbd75fbc-1d8d-483d-9da1-d78941b631b5} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt32(-1) as r FORMAT CSV;) 2025.03.31 19:03:34.527604 [ 6194 ] {fbd75fbc-1d8d-483d-9da1-d78941b631b5} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:34.896389 [ 6194 ] {ba80ae8a-1aff-4fc4-9f90-37fdc066cc75} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) <= N as r FORMAT CSV;) 2025.03.31 19:03:34.897394 [ 6194 ] {ba80ae8a-1aff-4fc4-9f90-37fdc066cc75} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:35.122524 [ 6194 ] {e72e9d4d-de51-4d80-8028-84e8640bb735} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toUInt64(1) as r FORMAT CSV;) 2025.03.31 19:03:35.123340 [ 6194 ] {e72e9d4d-de51-4d80-8028-84e8640bb735} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:35.183907 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:35.264642 [ 6194 ] {563e9f25-ec06-4a7c-a003-21509f4ac78a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) <= N as r FORMAT CSV;) 2025.03.31 19:03:35.265586 [ 6194 ] {563e9f25-ec06-4a7c-a003-21509f4ac78a} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:35.444596 [ 6194 ] {f38e92f3-da61-4669-8396-86fada4e76e2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N <= toInt64(-1) as r FORMAT CSV;) 2025.03.31 19:03:35.445401 [ 6194 ] {f38e92f3-da61-4669-8396-86fada4e76e2} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N <= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:36.014963 [ 6194 ] {331d6d68-d13d-4c67-b650-d8f451b7fe2e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) <= N as r FORMAT CSV;) 2025.03.31 19:03:36.016028 [ 6194 ] {331d6d68-d13d-4c67-b650-d8f451b7fe2e} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function lessOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) <= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:36.211345 [ 6194 ] {e6f60678-1224-4679-bc44-5a93e03bf64f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt8(1) as r FORMAT CSV;) 2025.03.31 19:03:36.212411 [ 6194 ] {e6f60678-1224-4679-bc44-5a93e03bf64f} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:36.301506 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:36.356742 [ 6194 ] {1b98ddef-e713-4e4d-852d-2767cf12a14b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) > N as r FORMAT CSV;) 2025.03.31 19:03:36.357697 [ 6194 ] {1b98ddef-e713-4e4d-852d-2767cf12a14b} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:36.724884 [ 6194 ] {324fc597-d310-4f91-bde0-34f8a105e971} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt8(-1) as r FORMAT CSV;) 2025.03.31 19:03:36.726102 [ 6194 ] {324fc597-d310-4f91-bde0-34f8a105e971} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:36.787151 [ 6194 ] {a4cf0205-701d-42fe-bf44-27b8894b3b10} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, DT64 as N SELECT toTypeName(r), N > toInt8(-1) as r FORMAT CSV;) 2025.03.31 19:03:36.788259 [ 6194 ] {a4cf0205-701d-42fe-bf44-27b8894b3b10} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:03:36.924396 [ 6194 ] {5bcd43f8-ada7-40b1-882f-828cd28996d6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: SELECT '------------------------------------------';) 2025.03.31 19:03:36.925481 [ 6194 ] {5bcd43f8-ada7-40b1-882f-828cd28996d6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:03:36.971693 [ 6194 ] {b1242bb9-580d-434b-9436-f5bb90c0e89e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) > N as r FORMAT CSV;) 2025.03.31 19:03:36.972714 [ 6194 ] {b1242bb9-580d-434b-9436-f5bb90c0e89e} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:37.239709 [ 6194 ] {0ace5f5c-a0fb-48e6-9866-77e4dff7ba5d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt16(1) as r FORMAT CSV;) 2025.03.31 19:03:37.240777 [ 6194 ] {0ace5f5c-a0fb-48e6-9866-77e4dff7ba5d} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:37.396213 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:37.417895 [ 6194 ] {71820e52-c196-4bda-97a1-101ac2a98c2e} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) > N as r FORMAT CSV;) 2025.03.31 19:03:37.418774 [ 6194 ] {71820e52-c196-4bda-97a1-101ac2a98c2e} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:37.551214 [ 6194 ] {af459aca-5435-4cd7-83db-3d4e54e98733} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt16(-1) as r FORMAT CSV;) 2025.03.31 19:03:37.552164 [ 6194 ] {af459aca-5435-4cd7-83db-3d4e54e98733} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:37.856877 [ 6194 ] {b2ff529e-5e5b-4d83-9a30-a49267d8e45a} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) > N as r FORMAT CSV;) 2025.03.31 19:03:37.857863 [ 6194 ] {b2ff529e-5e5b-4d83-9a30-a49267d8e45a} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:38.102157 [ 6194 ] {5b00b353-a98e-432f-9c8f-61a7219c72e2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt32(1) as r FORMAT CSV;) 2025.03.31 19:03:38.103042 [ 6194 ] {5b00b353-a98e-432f-9c8f-61a7219c72e2} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:38.353396 [ 6194 ] {29823cd6-057d-443a-af06-e674a54be90d} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) > N as r FORMAT CSV;) 2025.03.31 19:03:38.354415 [ 6194 ] {29823cd6-057d-443a-af06-e674a54be90d} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:38.488960 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:38.492832 [ 6194 ] {248b1841-93d5-4397-a378-e1b23906f1be} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt32(-1) as r FORMAT CSV;) 2025.03.31 19:03:38.493861 [ 6194 ] {248b1841-93d5-4397-a378-e1b23906f1be} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:38.773009 [ 6194 ] {8f4caa89-c220-4444-ab9e-dfa8d1156892} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) > N as r FORMAT CSV;) 2025.03.31 19:03:38.774194 [ 6194 ] {8f4caa89-c220-4444-ab9e-dfa8d1156892} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:39.017679 [ 6194 ] {bd5c4019-2576-469e-bdb7-26cefc6b3e56} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toUInt64(1) as r FORMAT CSV;) 2025.03.31 19:03:39.018942 [ 6194 ] {bd5c4019-2576-469e-bdb7-26cefc6b3e56} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:39.276657 [ 6194 ] {6fc7acda-ed0c-4d53-8101-939ff39a7d23} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) > N as r FORMAT CSV;) 2025.03.31 19:03:39.277614 [ 6194 ] {6fc7acda-ed0c-4d53-8101-939ff39a7d23} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:39.519907 [ 6194 ] {99608635-bff7-445e-abe4-60c6423697bc} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N > toInt64(-1) as r FORMAT CSV;) 2025.03.31 19:03:39.521128 [ 6194 ] {99608635-bff7-445e-abe4-60c6423697bc} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N > toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:39.544090 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:39.652730 [ 6194 ] {3be5c337-871d-405c-bf9d-ea6744fd4d46} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) > N as r FORMAT CSV;) 2025.03.31 19:03:39.653875 [ 6194 ] {3be5c337-871d-405c-bf9d-ea6744fd4d46} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) > N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:39.783375 [ 6194 ] {a4b2be82-6215-424c-8acb-c4bd7aa956b1} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt8(1) as r FORMAT CSV;) 2025.03.31 19:03:39.784220 [ 6194 ] {a4b2be82-6215-424c-8acb-c4bd7aa956b1} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt8(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:39.919866 [ 6194 ] {2f2c1fdb-db7a-4cf3-9122-1335d888e970} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt8(1) >= N as r FORMAT CSV;) 2025.03.31 19:03:39.920770 [ 6194 ] {2f2c1fdb-db7a-4cf3-9122-1335d888e970} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt8(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:40.133962 [ 6194 ] {2596f64b-1723-47ed-8385-03bc225e1a33} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt8(-1) as r FORMAT CSV;) 2025.03.31 19:03:40.134841 [ 6194 ] {2596f64b-1723-47ed-8385-03bc225e1a33} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int8) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt8(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:40.368367 [ 6194 ] {1c18c287-3914-4fcb-9878-aed658e7f3a2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt8(-1) >= N as r FORMAT CSV;) 2025.03.31 19:03:40.369394 [ 6194 ] {1c18c287-3914-4fcb-9878-aed658e7f3a2} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt8(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:40.561618 [ 6194 ] {4e4e3617-f20e-48b3-9549-f03771bdb70c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt16(1) as r FORMAT CSV;) 2025.03.31 19:03:40.629216 [ 6194 ] {4e4e3617-f20e-48b3-9549-f03771bdb70c} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt16(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:40.658587 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:40.870539 [ 6194 ] {1aa80b7d-45d3-45ee-a0a8-ae37e9d1499c} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt16(1) >= N as r FORMAT CSV;) 2025.03.31 19:03:40.871539 [ 6194 ] {1aa80b7d-45d3-45ee-a0a8-ae37e9d1499c} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt16(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:41.143816 [ 6194 ] {9e92ad31-433e-45e5-819e-0be7f029f9d8} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt16(-1) as r FORMAT CSV;) 2025.03.31 19:03:41.144743 [ 6194 ] {9e92ad31-433e-45e5-819e-0be7f029f9d8} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int16) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt16(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:41.278996 [ 6107 ] {b9b4afb9-aa14-424e-900c-7ba33513dd4a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57984) (comment: 00800_versatile_storage_join.sql) (in query: DROP DATABASE IF EXISTS test_pi3nomtb ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:03:41.280711 [ 6107 ] {b9b4afb9-aa14-424e-900c-7ba33513dd4a} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:03:41.312420 [ 3830 ] {28cb0b62-f62e-411c-b6e0-04b23cdf67ad} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44960) (comment: 00800_versatile_storage_join.sql) (in query: DROP DATABASE IF EXISTS test_pi3nomtb ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:03:41.314212 [ 3830 ] {28cb0b62-f62e-411c-b6e0-04b23cdf67ad} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:03:41.445422 [ 6194 ] {16bee03a-ad8f-46b8-a3dc-b8cce19a34c8} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt16(-1) >= N as r FORMAT CSV;) 2025.03.31 19:03:41.446392 [ 6194 ] {16bee03a-ad8f-46b8-a3dc-b8cce19a34c8} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt16(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:41.575130 [ 6194 ] {a9735f08-76c7-4893-aa59-f6c0a5c58ac9} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt32(1) as r FORMAT CSV;) 2025.03.31 19:03:41.576092 [ 6194 ] {a9735f08-76c7-4893-aa59-f6c0a5c58ac9} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt32(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:41.937961 [ 6194 ] {358d7652-39b1-46a8-a83a-441d0777e0a9} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt32(1) >= N as r FORMAT CSV;) 2025.03.31 19:03:41.939046 [ 6194 ] {358d7652-39b1-46a8-a83a-441d0777e0a9} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt32(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:41.943607 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:42.158085 [ 6194 ] {c40d00da-7297-4b51-bb81-122c6a017b79} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt32(-1) as r FORMAT CSV;) 2025.03.31 19:03:42.158967 [ 6194 ] {c40d00da-7297-4b51-bb81-122c6a017b79} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int32) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt32(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:42.620307 [ 6194 ] {480d943c-d38c-4f9e-b782-1581547ab320} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt32(-1) >= N as r FORMAT CSV;) 2025.03.31 19:03:42.621347 [ 6194 ] {480d943c-d38c-4f9e-b782-1581547ab320} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt32(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:42.954291 [ 6194 ] {129895f4-79bf-42c0-b7d3-ec163bcf242b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toUInt64(1) as r FORMAT CSV;) 2025.03.31 19:03:42.955223 [ 6194 ] {129895f4-79bf-42c0-b7d3-ec163bcf242b} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, UInt64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toUInt64(1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:43.024123 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:43.147384 [ 6194 ] {ccbc4b41-8233-42e1-9893-7033464d61c9} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toUInt64(1) >= N as r FORMAT CSV;) 2025.03.31 19:03:43.148438 [ 6194 ] {ccbc4b41-8233-42e1-9893-7033464d61c9} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toUInt64(1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:43.329388 [ 3830 ] {131bcc04-e91c-4783-9e21-ed9d01a53f2a} executeQuery: Code: 57. DB::Exception: Table test_2rtw9kvv.set already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59066) (comment: 00475_in_join_db_table.sql) (in query: CREATE TABLE set (x String) ENGINE = Set;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:43.424187 [ 3830 ] {131bcc04-e91c-4783-9e21-ed9d01a53f2a} TCPHandler: Code: 57. DB::Exception: Table test_2rtw9kvv.set 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:43.453927 [ 6194 ] {e87d51a3-95ad-45f8-91b6-fc9fec935282} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), N >= toInt64(-1) as r FORMAT CSV;) 2025.03.31 19:03:43.455008 [ 6194 ] {e87d51a3-95ad-45f8-91b6-fc9fec935282} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Date, Int64) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), N >= toInt64(-1) AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:43.773498 [ 6194 ] {292b2909-c7b1-49be-9bfb-3f0515353ad8} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40132) (comment: 00921_datetime64_compatibility_long.sh) (in query: WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') as DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') as DT, toDate('2019-09-16') as D, D as N SELECT toTypeName(r), toInt64(-1) >= N as r FORMAT CSV;) 2025.03.31 19:03:43.774620 [ 6194 ] {292b2909-c7b1-49be-9bfb-3f0515353ad8} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greaterOrEquals: In scope WITH toDateTime64('2019-09-16 19:20:11.234', 3, 'Europe/Minsk') AS DT64, toDateTime('2019-09-16 19:20:11', 'Europe/Minsk') AS DT, toDate('2019-09-16') AS D, D AS N SELECT toTypeName(r), toInt64(-1) >= N AS r. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.03.31 19:03:44.144537 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:45.362552 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:45.419129 [ 4240 ] {c6e824a1-d20d-4d29-afc5-568ad6921475} 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.10457.altinitytest (altinity build)) (from [::1]:59098) (comment: 02346_to_hour_monotonicity_fix.sql) (in query: select toHour(toTimeZone(t, 'UTC')) as toHour_UTC, toHour(toTimeZone(t, 'Asia/Jerusalem')) as toHour_Israel, count() from test_tz_hour where toHour_Israel = 8 group by toHour_UTC, toHour_Israel;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:03:45.424880 [ 4240 ] {c6e824a1-d20d-4d29-afc5-568ad6921475} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:03:46.480715 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:47.587747 [ 3863 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:48.763481 [ 2856 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:48.814386 [ 3830 ] {d31a9637-5190-44f9-b276-2178b0021b74} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45070) (comment: 02567_and_consistency.sql) (in query: DROP DATABASE IF EXISTS test_dhovub68 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:03:48.816285 [ 3830 ] {d31a9637-5190-44f9-b276-2178b0021b74} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:03:48.829283 [ 4187 ] {df054597-a432-49b9-8fcc-fba8debd4b20} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45074) (comment: 02567_and_consistency.sql) (in query: DROP DATABASE IF EXISTS test_dhovub68 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:03:48.831099 [ 4187 ] {df054597-a432-49b9-8fcc-fba8debd4b20} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:03:49.848855 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:51.016524 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:52.332561 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:53.412563 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:53.639657 [ 2856 ] {5cf16fba-3823-4bd9-8865-71a1010b07fc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60198) (comment: 03165_string_functions_with_token_text_indexes.sql) (in query: SELECT '';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:53.641567 [ 2856 ] {5cf16fba-3823-4bd9-8865-71a1010b07fc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:53.747986 [ 3028 ] {} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339b83d8 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339b942e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339da35f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 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*) @ 0x00000000319a464f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:03:54.539551 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:55.341043 [ 3863 ] {8578dfb4-4565-444c-8b3a-a56bed459d9a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60288) (comment: 03203_client_benchmark_options.sh) (in query: SELECT sum(number) FROM numbers(10_000) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:03:55.343640 [ 3863 ] {8578dfb4-4565-444c-8b3a-a56bed459d9a} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:03:55.658907 [ 3863 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:55.719358 [ 4187 ] {f0108e33-673a-48e7-a92f-02ecb99f9df3} executeQuery: Code: 69. DB::Exception: Overflow in internal computations in function groupArrayResample. Too large arguments. (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60268) (comment: 01463_resample_overflow.sql) (in query: select groupArrayResample(-9223372036854775808, 9223372036854775807, 9223372036854775807)(number, toInt64(number)) FROM numbers(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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./src/AggregateFunctions/Combinators/AggregateFunctionResample.h:69: DB::AggregateFunctionResample::AggregateFunctionResample(std::shared_ptr, long, long, unsigned long, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fdb7283 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fdb5fe6 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::(anonymous namespace)::AggregateFunctionCombinatorResample::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fdac92c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306db675 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d6259 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349e86e 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:03:55.720570 [ 4187 ] {f0108e33-673a-48e7-a92f-02ecb99f9df3} TCPHandler: Code: 69. DB::Exception: Overflow in internal computations in function groupArrayResample. Too large arguments. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./src/AggregateFunctions/Combinators/AggregateFunctionResample.h:69: DB::AggregateFunctionResample::AggregateFunctionResample(std::shared_ptr, long, long, unsigned long, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fdb7283 5. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr> std::allocate_shared[abi:v15007], std::allocator>, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&, void>(std::allocator> const&, std::shared_ptr const&, long&, long&, unsigned long&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x000000002fdb5fe6 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::(anonymous namespace)::AggregateFunctionCombinatorResample::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fdac92c 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306db675 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d6259 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349e86e 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:03:55.907181 [ 6107 ] {7461682d-fe75-4e19-8657-35c539191c29} executeQuery: Code: 57. DB::Exception: Table test_iqg5y8dq.test_with_merge_limit already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60292) (comment: 02473_optimize_old_parts.sh) (in query: CREATE TABLE test_with_merge_limit (`i` Int64) ENGINE = MergeTree PARTITION BY i ORDER BY i SETTINGS min_age_to_force_merge_seconds = 1, merge_selecting_sleep_ms = 1000, min_age_to_force_merge_on_partition_only = true, enable_max_bytes_limit_for_min_age_to_force_merge = true, max_bytes_to_merge_at_max_space_in_pool = 1, index_granularity = 39197, min_bytes_for_wide_part = 313093452, ratio_of_defaults_for_sparse_serialization = 0.764945924282074, replace_long_file_name_to_hash = false, max_file_name_length = 5, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 409556652, compact_parts_max_granules_to_buffer = 219, compact_parts_merge_max_bytes_to_prefetch_part = 16379052, merge_max_block_size = 11156, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 61, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 10274951, concurrent_part_removal_threshold = 54, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 11792, primary_key_compress_block_size = 19375), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:55.909357 [ 6107 ] {7461682d-fe75-4e19-8657-35c539191c29} TCPHandler: Code: 57. DB::Exception: Table test_iqg5y8dq.test_with_merge_limit 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:56.728418 [ 2856 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:56.799347 [ 3863 ] {3c9eed2b-500e-424a-8317-9cb3ccf35a73} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60298) (comment: 02494_query_cache_case_agnostic_matching.sql) (in query: -- There should still be just one entry in the QC SELECT COUNT(*) FROM system.query_cache;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:56.801688 [ 3863 ] {3c9eed2b-500e-424a-8317-9cb3ccf35a73} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:57.793508 [ 2856 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:58.217282 [ 3863 ] {874d4300-23fa-4aec-9294-2c96e8d5f16b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60314) (comment: 01268_data_numeric_parameters.sql) (in query: SELECT toTypeName(a), toTypeName(b), toTypeName(c), toTypeName(d), toTypeName(e), toTypeName(f) FROM floats;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:58.219798 [ 3863 ] {874d4300-23fa-4aec-9294-2c96e8d5f16b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:03:58.947943 [ 2856 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:03:59.988629 [ 6194 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:00.654278 [ 3608 ] {e5bdd41b-73db-4776-8d64-31ef3a8dbb3a::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:01.039740 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:01.215435 [ 6107 ] {bf2df4f8-d34e-4a03-ba94-0c074f5aa6dd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38678) (comment: 02473_optimize_old_parts.sh) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_with_merge_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:04:01.284287 [ 6107 ] {bf2df4f8-d34e-4a03-ba94-0c074f5aa6dd} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:04:01.452573 [ 6194 ] {bd2ebb50-c0a5-4f99-9380-de39a56b5e9d} executeQuery: Code: 341. DB::Exception: Mutation mutation_2.txt was killed. (UNFINISHED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38662) (comment: 01710_projection_materialize_with_missing_columns.sql) (in query: alter table x materialize projection p_agg settings mutations_sync = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfbd92 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:01.456515 [ 6194 ] {bd2ebb50-c0a5-4f99-9380-de39a56b5e9d} TCPHandler: Code: 341. DB::Exception: Mutation mutation_2.txt was killed. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfbd92 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:01.686606 [ 3608 ] {e5bdd41b-73db-4776-8d64-31ef3a8dbb3a::all_1_1_0_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039d03d22 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f91bf1 19. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000034f9c58b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e68dd2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aa57c 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:02.136989 [ 2856 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:03.213006 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:03.944872 [ 6194 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:04.218184 [ 6194 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:04.319339 [ 6194 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:04.918825 [ 2856 ] {e242cfc5-4529-43e2-80e1-8d70de8e906d} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -256, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT ignore(lcm(-256, 9223372036854775807)). (DECIMAL_OVERFLOW) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38688) (comment: 01435_lcm_overflow.sql) (in query: SELECT ignore(lcm(-256, 9223372036854775807));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf1f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(short, unsigned long) @ 0x000000001411473a 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISE_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001425fdfe 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001416e2ed 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001415e17b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415a408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014156abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 2025.03.31 19:04:04.919968 [ 2856 ] {e242cfc5-4529-43e2-80e1-8d70de8e906d} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -256, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT ignore(lcm(-256, 9223372036854775807)). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000fdf1f3f 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameLCM>::apply(short, unsigned long) @ 0x000000001411473a 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17LCMImplENS12_7NameLCMELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISE_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000001425fdfe 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001416e2ed 7. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001415e17b 8. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001415a408 9. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014156abc 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 22. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 25. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 2025.03.31 19:04:05.063974 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:05.358769 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:05.840091 [ 6194 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:06.519379 [ 6194 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:06.628613 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:07.395814 [ 6194 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:07.589418 [ 6194 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:08.169621 [ 2856 ] {f53f6b93-654a-404c-a7f8-900a92e1a109} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39712) (comment: 00976_shard_low_cardinality_achimbab.sql) (in query: DROP DATABASE IF EXISTS test_0six294o ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:04:08.171534 [ 2856 ] {f53f6b93-654a-404c-a7f8-900a92e1a109} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:08.173570 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:08.224577 [ 6194 ] {1ae9c3c5-5d15-4d37-a0a9-ea4dd5e0f81a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39726) (comment: 00976_shard_low_cardinality_achimbab.sql) (in query: DROP DATABASE IF EXISTS test_0six294o ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:04:08.226360 [ 6194 ] {1ae9c3c5-5d15-4d37-a0a9-ea4dd5e0f81a} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:08.239327 [ 2856 ] {58177cfa-b913-478a-857f-d6edcdededc3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39738) (comment: 00976_shard_low_cardinality_achimbab.sql) (in query: DROP DATABASE IF EXISTS test_0six294o ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:04:08.240999 [ 2856 ] {58177cfa-b913-478a-857f-d6edcdededc3} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:08.631391 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:08.955946 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:09.661177 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:09.752192 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:10.506033 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:10.710640 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:11.278906 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:11.754949 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:11.873188 [ 3610 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {44a6cca4-034c-4831-8768-cb7a26f63c3c::202503_1_56_16}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009656d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009133f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff77dff 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x0000000020113c7f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3a3572 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a0374 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:12.032550 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:12.780606 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:12.816294 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:13.540851 [ 6107 ] {17392c59-2e81-4b98-885b-96e076f14659} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38868) (comment: 02098_hashed_array_dictionary_simple_key.gen.sql) (in query: SELECT 'Dictionary hashed_array_dictionary_simple_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:04:13.542776 [ 6107 ] {17392c59-2e81-4b98-885b-96e076f14659} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:04:13.597475 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:13.817169 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:14.376820 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:14.894988 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:15.146803 [ 6107 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:15.899726 [ 3830 ] {7e821923-a5b9-443c-aae3-7e62697f0c80} executeQuery: Code: 50. DB::Exception: Unknown BSON type: 0x00: While executing BSONEachRowRowInputFormat. (UNKNOWN_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46426) (comment: 02684_bson.sql) (in query: -- It correctly throws exception about incorrect data: SELECT * FROM format('BSONEachRow', 'WatchID Int64, JavaEnable Int16, Title String, GoodEvent Int16, EventTime DateTime, EventDate Date, CounterID Int32, ClientIP Int32, RegionID Int32, UserID Int64, CounterClass Int16, OS Int16, UserAgent Int16, URL String, Referer String, IsRefresh Int16, RefererCategoryID Int16, RefererRegionID Int32, URLCategoryID Int16, URLRegionID Int32, ResolutionWidth Int16, ResolutionHeight Int16, ResolutionDepth Int16, FlashMajor Int16, FlashMinor Int16, FlashMinor2 String, NetMajor Int16, NetMinor Int16, UserAgentMajor Int16, UserAgentMinor String, CookieEnable Int16, JavascriptEnable Int16, IsMobile Int16, MobilePhone Int16, MobilePhoneModel String, Params String, IPNetworkID Int32, TraficSourceID Int16, SearchEngineID Int16, SearchPhrase String, AdvEngineID Int16, IsArtifical Int16, WindowClientWidth Int16, WindowClientHeight Int16, ClientTimeZone Int16, ClientEventTime DateTime, SilverlightVersion1 Int16, SilverlightVersion2 Int16, SilverlightVersion3 Int32, SilverlightVersion4 Int16, PageCharset String, CodeVersion Int32, IsLink Int16, IsDownload Int16, IsNotBounce Int16, FUniqID Int64, OriginalURL String, HID Int32, IsOldCounter Int16, IsEvent Int16, IsParameter Int16, DontCountHits Int16, WithHash Int16, HitColor String, LocalEventTime DateTime, Age Int16, Sex Int16, Income Int16, Interests Int16, Robotness Int16, RemoteIP Int32, WindowName Int32, OpenerName Int32, HistoryLength Int16, BrowserLanguage String, BrowserCountry String, SocialNetwork String, SocialAction String, HTTPError Int16, SendTiming Int32, DNSTiming Int32, ConnectTiming Int32, ResponseStartTiming Int32, ResponseEndTiming Int32, FetchTiming Int32, SocialSourceNetworkID Int16, SocialSourcePage String, ParamPrice Int64, ParamOrderID String, ParamCurrency String, ParamCurrencyID Int16, OpenstatServiceName String, OpenstatCampaignID String, OpenstatAdID String, OpenstatSourceID String, UTMSource String, UTMMedium String, UTMCampaign String, UTMContent String, UTMTerm String, FromTag String, HasGCLID Int16, RefererHash Int64, URLHash Int64, CLID Int32', $$^WatchIDc*5/ !p~JavaEnableTitleGoodEventEventTime7��QEventDate>CounterIDClientIP��z�RegionIDGUserID� ��:6��CounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID��9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZone����ClientEventTime��SilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime&��QAgeSexIncomeInterestsRobotnessRemoteIP^DI�WindowName����OpenerName����HistoryLength����BrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHash�|3��b.�CLID^WatchID��F�ӓ2qJavaEnableTitleGoodEventEventTimen$�QEventDate>CounterIDClientIP��z�RegionIDGUserID� ��:6��CounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthmingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHashv�v����CLID�WatchID���\JavaEnableTitleGoodEventEventTime� �QEventDate>CounterIDClientIP�gURegionID�UserID�s�yy��fCounterClassOS,UserAgentURL1http://tours/Ekategoriya%2F&sr=http://slovareniyeRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionID�ResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajor UserAgentMinorD�CookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID��TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZone����ClientEventTime��SilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTimeY��QAgeSexIncomeInterestsRobotnessRemoteIP�=kWindowName����OpenerName����HistoryLength����BrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHashh��9�DCLID^WatchID�/E��J�{JavaEnableTitleGoodEventEventTime�1�QEventDate>CounterIDClientIP��z�RegionIDGUserID� ��:6��CounterClassOSUserAgentURLRefererIsRefreshRefererCategoryIDRefererRegionIDURLCategoryIDURLRegionIDResolutionWidthResolutionHeightResolutionDepthFlashMajorFlashMinorFlashMinor2NetMajorNetMinorUserAgentMajorUserAgentMinor�OCookieEnableJavascriptEnableIsMobileMobilePhoneMobilePhoneModelParamsIPNetworkID��9TraficSourceIDSearchEngineIDSearchPhraseAdvEngineIDIsArtificalWindowClientWidthWindowClientHeightClientTimeZone����ClientEventTime��SilverlightVersion1SilverlightVersion2SilverlightVersion3SilverlightVersion4PageCharsetCodeVersionIsLinkIsDownloadIsNotBounceFUniqIDOriginalURLHIDIsOldCounterIsEventIsParameterDontCountHitsWithHashHitColor5LocalEventTime���QAgeSexIncomeInterestsRobotnessRemoteIP^DI�WindowName����OpenerName����HistoryLength����BrowserLanguage�BrowserCountry� SocialNetworkSocialActionHTTPErrorSendTimingDNSTimingConnectTimingResponseStartTimingResponseEndTimingFetchTimingSocialSourceNetworkIDSocialSourcePageParamPriceParamOrderIDParamCurrencyNHParamCurrencyIDOpenstatServiceNameOpenstatCampaignIDOpenstatAdIDOpenstatSourceIDUTMSourceUTMMediumUTMCampaignUTMContentUTMTermFromTagHasGCLIDRefererHashX+��'���URLHash�|3��b.�CLID$$);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Formats/BSONTypes.cpp:23: DB::getBSONType(unsigned char) @ 0x000000003b06ab45 5. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:0: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b05c986 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b01ef53 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aeb5ab9 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae2c8d3 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febc675 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f03b3 17. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003373d2f2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000334503f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334de021 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:04:15.900839 [ 3830 ] {7e821923-a5b9-443c-aae3-7e62697f0c80} TCPHandler: Code: 50. DB::Exception: Unknown BSON type: 0x00: While executing BSONEachRowRowInputFormat. (UNKNOWN_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Formats/BSONTypes.cpp:23: DB::getBSONType(unsigned char) @ 0x000000003b06ab45 5. ./build_docker/./src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:0: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b05c986 6. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b01ef53 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aeb5ab9 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae2c8d3 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 10. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 13. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 14. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 15. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002febc675 16. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f03b3 17. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003373d2f2 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000334503f1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334de021 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427080 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:04:15.943949 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:15.945412 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:16.696555 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:16.978172 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:17.477130 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:17.736554 [ 6107 ] {e8ea973e-7272-484b-9242-eab30a53f53f} executeQuery: Code: 36. DB::Exception: Aggregate function mannWhitneyUTest require both samples to be non empty. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46478) (comment: 01802_rank_corr_mann_whitney_over_window.sql) (in query: SELECT mannWhitneyUTest(salary, salary) OVER (ORDER BY salary ROWS BETWEEN CURRENT ROW AND UNBOUNDED FOLLOWING) AS func FROM 01802_empsalary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:234: DB::(anonymous namespace)::AggregateFunctionMannWhitney::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x000000002f614368 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003b9f26aa 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::work() @ 0x000000003b9fb87f 7. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 11. ./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*) @ 0x000000003ae9f89d 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:04:17.738710 [ 6107 ] {e8ea973e-7272-484b-9242-eab30a53f53f} TCPHandler: Code: 36. DB::Exception: Aggregate function mannWhitneyUTest require both samples to be non empty. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:234: DB::(anonymous namespace)::AggregateFunctionMannWhitney::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x000000002f614368 5. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003b9f26aa 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::work() @ 0x000000003b9fb87f 7. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 11. ./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*) @ 0x000000003ae9f89d 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:04:18.011800 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:18.278224 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:19.087024 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:19.162566 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:19.297889 [ 6107 ] {461d9fb8-5f78-4a52-8feb-c4943a80af40} executeQuery: Code: 36. DB::Exception: All numbers in both samples are identical. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46478) (comment: 01802_rank_corr_mann_whitney_over_window.sql) (in query: SELECT rankCorr(salary, 0.5) OVER (ORDER BY salary ASC ROWS BETWEEN CURRENT ROW AND UNBOUNDED FOLLOWING) AS func FROM 01802_empsalary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./src/AggregateFunctions/StatCommon.h:51: std::pair>, double> DB::computeRanksAndTieCorrection, DB::AlignedArenaAllocator<8ul>, 8ul>, 0ul, 0ul>>(DB::PODArray, DB::AlignedArenaAllocator<8ul>, 8ul>, 0ul, 0ul> const&) @ 0x000000002f6071d7 5. ./contrib/llvm-project/libcxx/include/vector:1352: DB::(anonymous namespace)::AggregateFunctionRankCorrelation::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x000000002f603435 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003b9f26aa 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::work() @ 0x000000003b9fb87f 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 12. ./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*) @ 0x000000003ae9f89d 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 2025.03.31 19:04:19.300129 [ 6107 ] {461d9fb8-5f78-4a52-8feb-c4943a80af40} TCPHandler: Code: 36. DB::Exception: All numbers in both samples are identical. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./src/AggregateFunctions/StatCommon.h:51: std::pair>, double> DB::computeRanksAndTieCorrection, DB::AlignedArenaAllocator<8ul>, 8ul>, 0ul, 0ul>>(DB::PODArray, DB::AlignedArenaAllocator<8ul>, 8ul>, 0ul, 0ul> const&) @ 0x000000002f6071d7 5. ./contrib/llvm-project/libcxx/include/vector:1352: DB::(anonymous namespace)::AggregateFunctionRankCorrelation::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x000000002f603435 6. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::appendChunk(DB::Chunk&) @ 0x000000003b9f26aa 7. ./build_docker/./src/Processors/Transforms/WindowTransform.cpp:0: DB::WindowTransform::work() @ 0x000000003b9fb87f 8. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 12. ./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*) @ 0x000000003ae9f89d 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 2025.03.31 19:04:19.891164 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:20.215805 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:20.665329 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:21.231484 [ 3830 ] {cadd6c6a-0ef2-4d76-88b2-91faa8415b67} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:43520) (comment: 02473_optimize_old_parts.sh) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_with_merge_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:04:21.234718 [ 3830 ] {cadd6c6a-0ef2-4d76-88b2-91faa8415b67} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:04:21.370254 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:21.391181 [ 4240 ] {c6656cc2-6804-42d0-bb80-3816a02729bc} executeQuery: Code: 388. DB::Exception: Cannot OPTIMIZE table: Did not find any parts to merge (with usual merge selectors). There is no need to merge parts according to merge selector algorithm. Cannot select parts for optimization. (CANNOT_ASSIGN_OPTIMIZE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:43498) (comment: 03001_consider_lwd_when_merge.sql) (in query: OPTIMIZE TABLE lwd_merge;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1654: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30db19 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bc951 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 2025.03.31 19:04:21.392283 [ 4240 ] {c6656cc2-6804-42d0-bb80-3816a02729bc} TCPHandler: Code: 388. DB::Exception: Cannot OPTIMIZE table: Did not find any parts to merge (with usual merge selectors). There is no need to merge parts according to merge selector algorithm. Cannot select parts for optimization. (CANNOT_ASSIGN_OPTIMIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Storages/StorageMergeTree.cpp:1654: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30db19 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bc951 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 2025.03.31 19:04:21.423817 [ 3863 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:21.856963 [ 3603 ] {f5d05746-8634-492f-86a3-4657e2a38865::all_2_2_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:21.857632 [ 3603 ] {f5d05746-8634-492f-86a3-4657e2a38865::all_2_2_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:22.010152 [ 3605 ] {f5d05746-8634-492f-86a3-4657e2a38865::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:22.184868 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:22.426924 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:22.604107 [ 4240 ] {54345aa1-9f69-4dd6-b35b-8687c86644ce} executeQuery: Code: 341. DB::Exception: Mutation mutation_3.txt was killed. (UNFINISHED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:43498) (comment: 03001_consider_lwd_when_merge.sql) (in query: DELETE FROM lwd_merge WHERE id % 10 > 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfbd92 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x0000000035a6e6e3 10. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:118: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a684c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:04:22.605178 [ 4240 ] {54345aa1-9f69-4dd6-b35b-8687c86644ce} TCPHandler: Code: 341. DB::Exception: Mutation mutation_3.txt was killed. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfbd92 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x0000000035a6e6e3 10. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:118: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a684c6 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:04:22.700587 [ 2854 ] {9e83432f-f31b-4910-9c50-c87bb6199eee} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48380) (comment: 03001_consider_lwd_when_merge.sql) (in query: DROP DATABASE IF EXISTS test_2pjndeex ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:04:22.702422 [ 2854 ] {9e83432f-f31b-4910-9c50-c87bb6199eee} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:22.953350 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:23.014609 [ 3605 ] {f5d05746-8634-492f-86a3-4657e2a38865::all_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::checkIsNotCancelled() const @ 0x0000000034f45b18 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:137: DB::MergeTreeTransaction::addNewPart(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034f46672 6. ./contrib/llvm-project/libcxx/include/vector:1463: DB::MergeTreeTransaction::addNewPartAndRemoveCovered(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::MergeTreeTransaction*) @ 0x0000000034f47bf8 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::Transaction::commit(DB::DataPartsLock*) @ 0x000000003981d218 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aaedc 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:23.540310 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:23.750840 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:24.599112 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:24.608805 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:25.387611 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:25.540381 [ 3596 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c38c8cc9-27b1-4991-900a-4bc8e9c3b6da::202503_1_49_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:04:25.651973 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:26.171958 [ 3830 ] {7e5c1274-5f4e-45a7-b9a8-f60ea6a104db} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:43588) (comment: 02420_final_setting_analyzer.sql) (in query: -- expected output is 1 because final == 1 select count() from lhs inner join rhs on lhs.x = rhs.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:04:26.174033 [ 3830 ] {7e5c1274-5f4e-45a7-b9a8-f60ea6a104db} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:04:26.248481 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:26.758595 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:27.108334 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:27.841407 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:27.883038 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:28.662871 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:28.908265 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:29.478034 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:30.035255 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:30.304989 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:31.094074 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:31.117944 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:31.902813 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:32.172980 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:32.724956 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:33.265425 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:33.489102 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:34.252214 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:34.407164 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:35.029161 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:35.441327 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:35.797638 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:36.570825 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:36.586006 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:37.357989 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:37.649904 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:38.138336 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:38.744531 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:38.897054 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:39.647936 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:39.786572 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:40.426891 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:40.818068 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:41.236418 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:41.931752 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:42.000002 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:42.795542 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:43.019840 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:43.637832 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:44.110501 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:44.438396 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:45.203958 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:45.239666 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:46.021007 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:46.256428 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:46.790513 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:47.363631 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:47.563410 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:48.330677 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:48.402044 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:49.104301 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:49.475937 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:49.926544 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:50.549038 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:50.704528 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:51.484940 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:51.625612 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:52.250992 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:52.700033 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:53.020920 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:53.789443 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:53.806584 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:54.566236 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:54.825964 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:55.387336 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:55.919726 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:56.194632 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:56.937290 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:57.046010 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:57.832974 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:58.062188 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:58.727957 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:59.172612 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:04:59.487145 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:00.217560 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:00.345645 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:01.115646 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:01.284398 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:01.956750 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:02.467073 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:02.751329 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:03.544535 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:03.546880 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:04.320937 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:04.605007 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:04.723048 [ 3830 ] {8c343d7c-8ad9-4d37-9fca-1bfb9b1f3fc8} 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.10457.altinitytest (altinity build)) (from [::1]:44022) (comment: 02473_optimize_old_parts.sh) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_with_merge_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:05:04.725664 [ 3830 ] {8c343d7c-8ad9-4d37-9fca-1bfb9b1f3fc8} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:05:05.093074 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:05.654948 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:05.876644 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:06.679629 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:06.774214 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:07.455506 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:07.845261 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:08.229259 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:08.872908 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:09.003649 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:09.794243 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:09.976674 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:10.567913 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:11.181595 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:11.328843 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:12.112260 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:12.181439 [ 3610 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {44a6cca4-034c-4831-8768-cb7a26f63c3c::202503_1_62_22}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009656d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009133f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff77dff 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x0000000020113c7f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3a3572 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a0374 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:05:12.349597 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:12.899413 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:13.398985 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:13.702259 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:14.471344 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:14.504676 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:15.297392 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:15.552810 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:16.060035 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:16.605946 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:16.837904 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:17.679263 [ 3863 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:17.714580 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:18.517325 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:18.744049 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:19.276255 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:19.850753 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:20.066218 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:20.824321 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:20.935785 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:21.626376 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:22.103691 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:22.413659 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:23.145910 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:23.183296 [ 3863 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:23.448700 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:23.735835 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:23.992006 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:24.188171 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:25.232414 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:26.132882 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:26.263580 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:26.639094 [ 2854 ] {40fe2d1c-f651-4e14-b3eb-f7e8d11435d8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48400) (comment: 02420_final_setting_analyzer.sql) (in query: DROP DATABASE IF EXISTS test_snh1yfh8 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:05:26.641127 [ 2854 ] {40fe2d1c-f651-4e14-b3eb-f7e8d11435d8} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:05:26.755061 [ 3863 ] {e8963bea-fdfd-4e59-bea8-d8c5c4c2e80b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:53436) (comment: 02420_final_setting_analyzer.sql) (in query: DROP DATABASE IF EXISTS test_snh1yfh8 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:05:26.756807 [ 3863 ] {e8963bea-fdfd-4e59-bea8-d8c5c4c2e80b} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:05:27.388537 [ 3863 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:28.449837 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:29.576798 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:29.728392 [ 3830 ] {628a0328-0fec-4652-93d9-463e345aee4e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39034) (comment: 02158_ztest.sql) (in query: DROP DATABASE IF EXISTS test_5uily6wn ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:05:29.730258 [ 3830 ] {628a0328-0fec-4652-93d9-463e345aee4e} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:05:30.435170 [ 3863 ] {1eaaaf3e-12b1-440f-89ce-a612b360df7a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46008) (comment: 02473_optimize_old_parts.sh) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_with_merge_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:05:30.438245 [ 3863 ] {1eaaaf3e-12b1-440f-89ce-a612b360df7a} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:05:30.598229 [ 4187 ] {81615bc0-a319-4a80-9079-c92c42ca5c23} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57046) (comment: 02425_categorical_information_value_properties.sql) (in query: SELECT categoricalInformationValue(c1, c2) FROM VALUES((NULL, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f5f0944 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b0923 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dbb01 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:113: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d5a70 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349e86e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:05:30.599306 [ 4187 ] {81615bc0-a319-4a80-9079-c92c42ca5c23} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f5f0944 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b0923 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dbb01 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:113: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d5a70 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349e86e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:05:30.657228 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:30.814602 [ 4187 ] {02f6abe6-f1d2-4613-8638-7f617f00949e} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57046) (comment: 02425_categorical_information_value_properties.sql) (in query: SELECT categoricalInformationValue(c1, c2) FROM VALUES((NULL, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f5f0944 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b0923 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dbb01 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:113: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d5a70 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349e86e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:05:30.815578 [ 4187 ] {02f6abe6-f1d2-4613-8638-7f617f00949e} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:172: DB::(anonymous namespace)::createAggregateFunctionCategoricalIV(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002f5f0944 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002a2b0923 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dbb01 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:113: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d5a70 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3249: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349e86e 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:05:30.975892 [ 4187 ] {8fad38e4-ba09-4360-905f-c2f8078dde95} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57046) (comment: 02425_categorical_information_value_properties.sql) (in query: SELECT quantiles(0.5, 0.9)(c1) FROM VALUES(0::Nullable(UInt8));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:05:30.977459 [ 4187 ] {8fad38e4-ba09-4360-905f-c2f8078dde95} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:05:31.020427 [ 3830 ] {f271fe7b-5890-49cd-8d76-7c02fe9a14cb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39056) (comment: 01431_finish_sorting_with_consts.sql) (in query: DROP DATABASE IF EXISTS test_i3uoilpu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:05:31.022377 [ 3830 ] {f271fe7b-5890-49cd-8d76-7c02fe9a14cb} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:05:31.036009 [ 3485 ] {} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339b83d8 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339b942e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339da35f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 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*) @ 0x00000000319a464f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:05:31.680694 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:32.782977 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:33.862215 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:34.894869 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:35.909344 [ 3830 ] {5249ae72-018a-485c-86b6-fa7a9e5d051e} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT BIT_AND();) 2025.03.31 19:05:35.910988 [ 3830 ] {5249ae72-018a-485c-86b6-fa7a9e5d051e} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:35.956271 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:36.107563 [ 3830 ] {b2697d34-f7c9-4b6b-b438-938903fc1f84} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT BIT_OR();) 2025.03.31 19:05:36.109646 [ 3830 ] {b2697d34-f7c9-4b6b-b438-938903fc1f84} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.156941 [ 3830 ] {f647f46c-d764-457e-ab07-3db2b9714c5f} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT BIT_XOR();) 2025.03.31 19:05:36.158681 [ 3830 ] {f647f46c-d764-457e-ab07-3db2b9714c5f} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.175221 [ 3830 ] {bcede9cd-d899-40cd-bfaf-66d5a8b89d95} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 0, should be 1: In scope SELECT BLAKE3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT BLAKE3();) 2025.03.31 19:05:36.176607 [ 3830 ] {bcede9cd-d899-40cd-bfaf-66d5a8b89d95} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 0, should be 1: In scope SELECT BLAKE3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.202404 [ 3830 ] {4465612e-1f7f-4874-8138-d5df786463f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHARACTER_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT CHARACTER_LENGTH();) 2025.03.31 19:05:36.203793 [ 3830 ] {4465612e-1f7f-4874-8138-d5df786463f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHARACTER_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.222640 [ 3830 ] {adccaf2e-3ca0-439b-9738-58384327398f} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHAR_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT CHAR_LENGTH();) 2025.03.31 19:05:36.224012 [ 3830 ] {adccaf2e-3ca0-439b-9738-58384327398f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT CHAR_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.242996 [ 3830 ] {a99e34f5-8b95-476a-b760-6234e7c04cea} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT COVAR_POP();) 2025.03.31 19:05:36.244541 [ 3830 ] {a99e34f5-8b95-476a-b760-6234e7c04cea} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.314642 [ 3830 ] {48862814-922d-491f-8132-ab8a9266c9b2} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT COVAR_SAMP();) 2025.03.31 19:05:36.316111 [ 3830 ] {48862814-922d-491f-8132-ab8a9266c9b2} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.344413 [ 3830 ] {b6ae40b1-bf97-4669-8a42-cbea227744fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 0, should be 1: In scope SELECT CRC32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT CRC32();) 2025.03.31 19:05:36.347571 [ 3830 ] {b6ae40b1-bf97-4669-8a42-cbea227744fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 0, should be 1: In scope SELECT CRC32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.366474 [ 3830 ] {26f18349-8a33-48fe-9e45-ac0b19eec0c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 0, should be 1: In scope SELECT CRC32IEEE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT CRC32IEEE();) 2025.03.31 19:05:36.368183 [ 3830 ] {26f18349-8a33-48fe-9e45-ac0b19eec0c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 0, should be 1: In scope SELECT CRC32IEEE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.387079 [ 3830 ] {72fa6058-fe94-4393-8064-095ee5b9cd20} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 0, should be 1: In scope SELECT CRC64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT CRC64();) 2025.03.31 19:05:36.388570 [ 3830 ] {72fa6058-fe94-4393-8064-095ee5b9cd20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 0, should be 1: In scope SELECT CRC64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.437741 [ 3830 ] {3e636fb5-5f50-4dcf-a877-54472c29cedc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT DATE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DATE();) 2025.03.31 19:05:36.439479 [ 3830 ] {3e636fb5-5f50-4dcf-a877-54472c29cedc} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT DATE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.458251 [ 3830 ] {e4ca123f-64be-4ef2-bbb6-e8835816a9ba} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DATE_DIFF();) 2025.03.31 19:05:36.459966 [ 3830 ] {e4ca123f-64be-4ef2-bbb6-e8835816a9ba} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.477858 [ 3830 ] {7a7c25ee-cc56-4938-939b-1072c136677b} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_FORMAT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DATE_FORMAT();) 2025.03.31 19:05:36.479427 [ 3830 ] {7a7c25ee-cc56-4938-939b-1072c136677b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_FORMAT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.498475 [ 3830 ] {f252e7df-074e-4ef0-ba00-71110d339185} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_TRUNC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DATE_TRUNC();) 2025.03.31 19:05:36.500024 [ 3830 ] {f252e7df-074e-4ef0-ba00-71110d339185} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT DATE_TRUNC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.521040 [ 3830 ] {e0c8bcde-0365-4744-82d7-8220ce0b621b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DAY();) 2025.03.31 19:05:36.599301 [ 3830 ] {e0c8bcde-0365-4744-82d7-8220ce0b621b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.618278 [ 3830 ] {71d08591-59b3-4853-adef-6fd6954e71ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFMONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DAYOFMONTH();) 2025.03.31 19:05:36.619722 [ 3830 ] {71d08591-59b3-4853-adef-6fd6954e71ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFMONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.637895 [ 3830 ] {2d57c7dc-6e93-4513-9663-f3bde702ff4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT DAYOFWEEK(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DAYOFWEEK();) 2025.03.31 19:05:36.639263 [ 3830 ] {2d57c7dc-6e93-4513-9663-f3bde702ff4f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT DAYOFWEEK(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.656828 [ 3830 ] {c45568f4-62e1-4c7d-8dc7-7201c7c551c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFYEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT DAYOFYEAR();) 2025.03.31 19:05:36.658429 [ 3830 ] {c45568f4-62e1-4c7d-8dc7-7201c7c551c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT DAYOFYEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.676804 [ 3830 ] {db239bf4-89bb-4a3a-b151-533df65e39b9} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT FORMAT_BYTES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT FORMAT_BYTES();) 2025.03.31 19:05:36.682593 [ 3718 ] {} BackupsWorker: Failed to restore from backup Disk('backups', '03032_async_backup_restore_test_lsupth4v'): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003074f71a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003074ef60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003074b4d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x0000000030729b4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003072ac6f 11. DB::ReadBuffer::next() @ 0x00000000095afaaf 12. ./build_docker/./src/IO/copyData.cpp:44: DB::(anonymous namespace)::copyDataImpl(DB::ReadBuffer&, DB::WriteBuffer&, bool, unsigned long, std::function, std::shared_ptr) @ 0x0000000020218d82 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000020218adf 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032eee9cb 15. ./build_docker/./src/Backups/BackupIO_Disk.cpp:0: DB::BackupReaderDisk::copyFileToDisk(String const&, unsigned long, bool, std::shared_ptr, String const&, DB::WriteMode) @ 0x000000003198993c 16. ./build_docker/./src/Backups/BackupImpl.cpp:862: DB::BackupImpl::copyFileToDisk(std::pair> const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x00000000318dfb2d 17. ./build_docker/./src/Backups/BackupImpl.cpp:0: DB::BackupImpl::copyFileToDisk(String const&, std::shared_ptr, String const&, DB::WriteMode) const @ 0x00000000318dedd7 18. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5714: DB::MergeTreeData::restorePartFromBackup(std::shared_ptr, DB::MergeTreePartInfo const&, String const&, bool) const @ 0x00000000397e653c 19. ./contrib/llvm-project/libcxx/include/string:1499: void std::__function::__policy_invoker::__call_impl, 7ul, std::allocator>>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003989ec60 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x0000000031896b1a 21. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b123d 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000318970ce 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:05:36.686718 [ 3830 ] {db239bf4-89bb-4a3a-b151-533df65e39b9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT FORMAT_BYTES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.734629 [ 3830 ] {dd9803a9-b3bd-40b6-9955-9be6c3f00249} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT FROM_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT FROM_BASE64();) 2025.03.31 19:05:36.736135 [ 3830 ] {dd9803a9-b3bd-40b6-9955-9be6c3f00249} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT FROM_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.754004 [ 3830 ] {7bb832ad-00d3-4f98-b5f7-4183b12335cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT FROM_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT FROM_DAYS();) 2025.03.31 19:05:36.755492 [ 3830 ] {7bb832ad-00d3-4f98-b5f7-4183b12335cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT FROM_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.773219 [ 3830 ] {0a65dfb9-9719-41d8-875c-3cc81f203a6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT FROM_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT FROM_UNIXTIME();) 2025.03.31 19:05:36.774723 [ 3830 ] {0a65dfb9-9719-41d8-875c-3cc81f203a6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT FROM_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.792536 [ 3830 ] {b22ebced-e031-4523-8ab9-28f166d9f83d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT HOUR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT HOUR();) 2025.03.31 19:05:36.794362 [ 3830 ] {b22ebced-e031-4523-8ab9-28f166d9f83d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT HOUR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.811570 [ 3830 ] {a97c200d-46a3-443d-9d91-3dfb629803ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET6_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT INET6_ATON();) 2025.03.31 19:05:36.812980 [ 3830 ] {a97c200d-46a3-443d-9d91-3dfb629803ed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET6_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.909112 [ 3830 ] {8ef76fe8-b714-4057-a56e-2a40b68f21cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT INET6_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT INET6_NTOA();) 2025.03.31 19:05:36.911203 [ 3830 ] {8ef76fe8-b714-4057-a56e-2a40b68f21cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT INET6_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:36.983119 [ 3830 ] {c44f2288-fb9c-4cf5-9ea0-8c328c10e3f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT INET_ATON();) 2025.03.31 19:05:36.984641 [ 3830 ] {c44f2288-fb9c-4cf5-9ea0-8c328c10e3f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT INET_ATON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.010390 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:37.037415 [ 3830 ] {4992cac7-ee5c-4cee-937e-fbf99aba558b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT INET_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT INET_NTOA();) 2025.03.31 19:05:37.039220 [ 3830 ] {4992cac7-ee5c-4cee-937e-fbf99aba558b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT INET_NTOA(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.059981 [ 3830 ] {4a079ec0-5bf8-489f-81b0-84eb3c76ccc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv4CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4CIDRToRange();) 2025.03.31 19:05:37.061832 [ 3830 ] {4a079ec0-5bf8-489f-81b0-84eb3c76ccc0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv4CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.081872 [ 3830 ] {9ea91557-15fe-479e-bf05-77bd24ffe67c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4NumToString();) 2025.03.31 19:05:37.083631 [ 3830 ] {9ea91557-15fe-479e-bf05-77bd24ffe67c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.101550 [ 3830 ] {7cb14fbc-e26a-4aec-be87-17f60ecba71d} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToStringClassC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4NumToStringClassC();) 2025.03.31 19:05:37.103081 [ 3830 ] {7cb14fbc-e26a-4aec-be87-17f60ecba71d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 0, should be 1: In scope SELECT IPv4NumToStringClassC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.122122 [ 3830 ] {3a1579cb-fa3c-44f1-9b89-0961680f0cb6} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4StringToNum();) 2025.03.31 19:05:37.123853 [ 3830 ] {3a1579cb-fa3c-44f1-9b89-0961680f0cb6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.148904 [ 3830 ] {92e2ad7d-5940-4040-921b-5af4c7a9c04a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4StringToNumOrDefault();) 2025.03.31 19:05:37.150574 [ 3830 ] {92e2ad7d-5940-4040-921b-5af4c7a9c04a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.169972 [ 3830 ] {bc42eb5a-ab98-4e24-ac93-aa25278716c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4StringToNumOrNull();) 2025.03.31 19:05:37.171704 [ 3830 ] {bc42eb5a-ab98-4e24-ac93-aa25278716c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv4StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.191187 [ 3830 ] {73f6d520-9cc9-4f4f-8951-a8c4721c4f3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 0, should be 1: In scope SELECT IPv4ToIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv4ToIPv6();) 2025.03.31 19:05:37.195488 [ 3830 ] {73f6d520-9cc9-4f4f-8951-a8c4721c4f3e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 0, should be 1: In scope SELECT IPv4ToIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.214464 [ 3830 ] {8fdf5aef-2d9f-4732-be20-63c519ffe650} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv6CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv6CIDRToRange();) 2025.03.31 19:05:37.216227 [ 3830 ] {8fdf5aef-2d9f-4732-be20-63c519ffe650} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6CIDRToRange doesn't match: passed 0, should be 2: In scope SELECT IPv6CIDRToRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.235978 [ 3830 ] {961b1791-8bf2-41c2-80db-2fcf8fce6a6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv6NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv6NumToString();) 2025.03.31 19:05:37.237654 [ 3830 ] {961b1791-8bf2-41c2-80db-2fcf8fce6a6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 0, should be 1: In scope SELECT IPv6NumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.256937 [ 3830 ] {3dd5d325-d275-4aa1-980e-130fd8417ebe} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv6StringToNum();) 2025.03.31 19:05:37.258756 [ 3830 ] {3dd5d325-d275-4aa1-980e-130fd8417ebe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.278364 [ 3830 ] {a376b46a-e242-45fa-8754-a0ff9fbd33c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv6StringToNumOrDefault();) 2025.03.31 19:05:37.279901 [ 3830 ] {a376b46a-e242-45fa-8754-a0ff9fbd33c0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.299431 [ 3830 ] {c433b7e5-a041-4f78-ac38-339cda868c93} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT IPv6StringToNumOrNull();) 2025.03.31 19:05:37.301193 [ 3830 ] {c433b7e5-a041-4f78-ac38-339cda868c93} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 0, should be 1: In scope SELECT IPv6StringToNumOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.320713 [ 3830 ] {42a9b485-a9ff-45e4-bb6e-70b2a260ecf5} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 0, should be 1: In scope SELECT JSONAllPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONAllPaths();) 2025.03.31 19:05:37.322276 [ 3830 ] {42a9b485-a9ff-45e4-bb6e-70b2a260ecf5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 0, should be 1: In scope SELECT JSONAllPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.414231 [ 3830 ] {1b0ec788-354a-4e27-ab43-5361521e4506} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONAllPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONAllPathsWithTypes();) 2025.03.31 19:05:37.415964 [ 3830 ] {1b0ec788-354a-4e27-ab43-5361521e4506} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONAllPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.433675 [ 3830 ] {d8dc72fe-0275-4fda-9fb9-45de0ad966ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSONArrayLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONArrayLength();) 2025.03.31 19:05:37.435287 [ 3830 ] {d8dc72fe-0275-4fda-9fb9-45de0ad966ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSONArrayLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.452295 [ 3830 ] {cda8a404-eef9-4d4d-8862-b282123019e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONDynamicPaths();) 2025.03.31 19:05:37.453887 [ 3830 ] {cda8a404-eef9-4d4d-8862-b282123019e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.548576 [ 3830 ] {3de9a2f7-bff2-4ec9-bba1-623f270c3d42} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONDynamicPathsWithTypes();) 2025.03.31 19:05:37.550266 [ 3830 ] {3de9a2f7-bff2-4ec9-bba1-623f270c3d42} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONDynamicPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.566826 [ 3830 ] {d3ac6303-52b4-436b-80d9-1e5ba74c0d4b} executeQuery: Code: 42. DB::Exception: Function JSONExtract requires at least two arguments: In scope SELECT JSONExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtract();) 2025.03.31 19:05:37.568248 [ 3830 ] {d3ac6303-52b4-436b-80d9-1e5ba74c0d4b} TCPHandler: Code: 42. DB::Exception: Function JSONExtract requires at least two arguments: In scope SELECT JSONExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.585387 [ 3830 ] {61557b6a-452e-4ebd-8038-6386e0f2ad22} executeQuery: Code: 42. DB::Exception: Function JSONExtractArrayRaw requires at least one argument: In scope SELECT JSONExtractArrayRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractArrayRaw();) 2025.03.31 19:05:37.587052 [ 3830 ] {61557b6a-452e-4ebd-8038-6386e0f2ad22} TCPHandler: Code: 42. DB::Exception: Function JSONExtractArrayRaw requires at least one argument: In scope SELECT JSONExtractArrayRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.604300 [ 3830 ] {9f568c6d-730c-4848-b7aa-e1462ee12590} executeQuery: Code: 42. DB::Exception: Function JSONExtractBool requires at least one argument: In scope SELECT JSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractBool();) 2025.03.31 19:05:37.605691 [ 3830 ] {9f568c6d-730c-4848-b7aa-e1462ee12590} TCPHandler: Code: 42. DB::Exception: Function JSONExtractBool requires at least one argument: In scope SELECT JSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.623245 [ 3830 ] {9a9c8453-c877-45a7-bd8b-25537a97e583} executeQuery: Code: 42. DB::Exception: Function JSONExtractFloat requires at least one argument: In scope SELECT JSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractFloat();) 2025.03.31 19:05:37.624729 [ 3830 ] {9a9c8453-c877-45a7-bd8b-25537a97e583} TCPHandler: Code: 42. DB::Exception: Function JSONExtractFloat requires at least one argument: In scope SELECT JSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.643025 [ 3830 ] {f2a3dab4-9465-44a5-938b-f39600916b99} executeQuery: Code: 42. DB::Exception: Function JSONExtractInt requires at least one argument: In scope SELECT JSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractInt();) 2025.03.31 19:05:37.644478 [ 3830 ] {f2a3dab4-9465-44a5-938b-f39600916b99} TCPHandler: Code: 42. DB::Exception: Function JSONExtractInt requires at least one argument: In scope SELECT JSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.663886 [ 3830 ] {330e459a-2a42-4fbf-8da4-0f352864705a} executeQuery: Code: 42. DB::Exception: Function JSONExtractKeys requires at least one argument: In scope SELECT JSONExtractKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractKeys();) 2025.03.31 19:05:37.665380 [ 3830 ] {330e459a-2a42-4fbf-8da4-0f352864705a} TCPHandler: Code: 42. DB::Exception: Function JSONExtractKeys requires at least one argument: In scope SELECT JSONExtractKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.684131 [ 3830 ] {3ee6c899-cded-4680-9a52-a3fba55200fe} executeQuery: Code: 42. DB::Exception: Function JSONExtractKeysAndValues requires at least two arguments: In scope SELECT JSONExtractKeysAndValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractKeysAndValues();) 2025.03.31 19:05:37.685577 [ 3830 ] {3ee6c899-cded-4680-9a52-a3fba55200fe} TCPHandler: Code: 42. DB::Exception: Function JSONExtractKeysAndValues requires at least two arguments: In scope SELECT JSONExtractKeysAndValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.784184 [ 3830 ] {e5bb6b13-b73d-4ac4-9a5a-5eed5e31a953} executeQuery: Code: 42. DB::Exception: Function JSONExtractKeysAndValuesRaw requires at least one argument: In scope SELECT JSONExtractKeysAndValuesRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractKeysAndValuesRaw();) 2025.03.31 19:05:37.785610 [ 3830 ] {e5bb6b13-b73d-4ac4-9a5a-5eed5e31a953} TCPHandler: Code: 42. DB::Exception: Function JSONExtractKeysAndValuesRaw requires at least one argument: In scope SELECT JSONExtractKeysAndValuesRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.804270 [ 3830 ] {56426a5f-26d3-4579-8354-d0b7d1b22078} executeQuery: Code: 42. DB::Exception: Function JSONExtractRaw requires at least one argument: In scope SELECT JSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractRaw();) 2025.03.31 19:05:37.805703 [ 3830 ] {56426a5f-26d3-4579-8354-d0b7d1b22078} TCPHandler: Code: 42. DB::Exception: Function JSONExtractRaw requires at least one argument: In scope SELECT JSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.826052 [ 3830 ] {bf0361b7-7b5c-4c53-bf67-7a0df67dc225} executeQuery: Code: 42. DB::Exception: Function JSONExtractString requires at least one argument: In scope SELECT JSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractString();) 2025.03.31 19:05:37.827981 [ 3830 ] {bf0361b7-7b5c-4c53-bf67-7a0df67dc225} TCPHandler: Code: 42. DB::Exception: Function JSONExtractString requires at least one argument: In scope SELECT JSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.846307 [ 3830 ] {adaaeb62-df6c-4bdc-9af3-496efcc0353d} executeQuery: Code: 42. DB::Exception: Function JSONExtractUInt requires at least one argument: In scope SELECT JSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONExtractUInt();) 2025.03.31 19:05:37.847983 [ 3830 ] {adaaeb62-df6c-4bdc-9af3-496efcc0353d} TCPHandler: Code: 42. DB::Exception: Function JSONExtractUInt requires at least one argument: In scope SELECT JSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.865354 [ 3830 ] {cdcb6c65-056a-444b-8599-1f6082fb5125} executeQuery: Code: 42. DB::Exception: Function JSONHas requires at least one argument: In scope SELECT JSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONHas();) 2025.03.31 19:05:37.867051 [ 3830 ] {cdcb6c65-056a-444b-8599-1f6082fb5125} TCPHandler: Code: 42. DB::Exception: Function JSONHas requires at least one argument: In scope SELECT JSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.886846 [ 3830 ] {783da86d-0111-4182-950b-7154699a57ae} executeQuery: Code: 42. DB::Exception: Function JSONKey requires at least one argument: In scope SELECT JSONKey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONKey();) 2025.03.31 19:05:37.888594 [ 3830 ] {783da86d-0111-4182-950b-7154699a57ae} TCPHandler: Code: 42. DB::Exception: Function JSONKey requires at least one argument: In scope SELECT JSONKey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:37.979248 [ 3830 ] {930ccd0d-79a2-452a-953e-ad2ce1199e35} executeQuery: Code: 42. DB::Exception: Function JSONLength requires at least one argument: In scope SELECT JSONLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONLength();) 2025.03.31 19:05:37.980696 [ 3830 ] {930ccd0d-79a2-452a-953e-ad2ce1199e35} TCPHandler: Code: 42. DB::Exception: Function JSONLength requires at least one argument: In scope SELECT JSONLength(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.039145 [ 3830 ] {939890bf-a06c-4eea-8a56-d25dac99c903} executeQuery: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT JSONMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONMergePatch();) 2025.03.31 19:05:38.040794 [ 3830 ] {939890bf-a06c-4eea-8a56-d25dac99c903} TCPHandler: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT JSONMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:38.059436 [ 3830 ] {f322ce05-3925-4d3e-9fd6-d15405a3e870} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONSharedDataPaths();) 2025.03.31 19:05:38.061151 [ 3830 ] {f322ce05-3925-4d3e-9fd6-d15405a3e870} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPaths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.078616 [ 3830 ] {e96c06ea-da03-4784-aa50-055770b8c87b} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONSharedDataPathsWithTypes();) 2025.03.31 19:05:38.080100 [ 3830 ] {e96c06ea-da03-4784-aa50-055770b8c87b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 0, should be 1: In scope SELECT JSONSharedDataPathsWithTypes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.097278 [ 3830 ] {c5a26778-3ee6-482d-af8a-5e157f597eb3} executeQuery: Code: 42. DB::Exception: Function JSONType requires at least one argument: In scope SELECT JSONType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSONType();) 2025.03.31 19:05:38.181799 [ 3830 ] {c5a26778-3ee6-482d-af8a-5e157f597eb3} TCPHandler: Code: 42. DB::Exception: Function JSONType requires at least one argument: In scope SELECT JSONType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.202175 [ 3830 ] {e56ec03c-1432-425e-8399-bbb899c5115f} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSON_ARRAY_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSON_ARRAY_LENGTH();) 2025.03.31 19:05:38.203962 [ 3830 ] {e56ec03c-1432-425e-8399-bbb899c5115f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 0, should be 1: In scope SELECT JSON_ARRAY_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.208777 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:38.261419 [ 3830 ] {4db8ce0e-6628-4af5-9a40-93d51106ef0c} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_EXISTS(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSON_EXISTS();) 2025.03.31 19:05:38.263293 [ 3830 ] {4db8ce0e-6628-4af5-9a40-93d51106ef0c} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_EXISTS(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:38.281392 [ 3830 ] {6f8c4a78-57b4-4423-b297-12ccc13ecf50} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_QUERY(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSON_QUERY();) 2025.03.31 19:05:38.283057 [ 3830 ] {6f8c4a78-57b4-4423-b297-12ccc13ecf50} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_QUERY(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:38.300955 [ 3830 ] {8c40a45a-736d-4e60-89f0-7e4c4b1acf52} executeQuery: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_VALUE(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT JSON_VALUE();) 2025.03.31 19:05:38.302671 [ 3830 ] {8c40a45a-736d-4e60-89f0-7e4c4b1acf52} TCPHandler: Code: 35. DB::Exception: JSONPath functions require at least 2 arguments: In scope SELECT JSON_VALUE(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:38.321906 [ 3830 ] {f587c1f2-ae03-4bd4-9ca0-825354e2f860} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT L1Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L1Distance();) 2025.03.31 19:05:38.323826 [ 3830 ] {f587c1f2-ae03-4bd4-9ca0-825354e2f860} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT L1Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.342061 [ 3830 ] {b493afd6-ebd3-4747-bb00-2c4a451379e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT L1Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L1Norm();) 2025.03.31 19:05:38.343857 [ 3830 ] {b493afd6-ebd3-4747-bb00-2c4a451379e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT L1Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.363915 [ 3830 ] {b83c4214-2c3b-46bd-af23-74f51dd92f3c} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT L1Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L1Normalize();) 2025.03.31 19:05:38.365643 [ 3830 ] {b83c4214-2c3b-46bd-af23-74f51dd92f3c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT L1Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.383011 [ 3830 ] {8bf6a340-2d80-477c-a13e-d948e2798123} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT L2Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L2Distance();) 2025.03.31 19:05:38.384690 [ 3830 ] {8bf6a340-2d80-477c-a13e-d948e2798123} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT L2Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.403052 [ 3830 ] {113a6a8b-735a-4295-bf58-9ee03152a44f} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT L2Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L2Norm();) 2025.03.31 19:05:38.404774 [ 3830 ] {113a6a8b-735a-4295-bf58-9ee03152a44f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT L2Norm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.422237 [ 3830 ] {8abee4dd-e27b-45f1-93db-ddf04b42c966} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT L2Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L2Normalize();) 2025.03.31 19:05:38.423674 [ 3830 ] {8abee4dd-e27b-45f1-93db-ddf04b42c966} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT L2Normalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.480186 [ 3830 ] {e975932e-b843-4e34-9a0d-8c7ac4b1bf82} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT L2SquaredDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L2SquaredDistance();) 2025.03.31 19:05:38.482001 [ 3830 ] {e975932e-b843-4e34-9a0d-8c7ac4b1bf82} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT L2SquaredDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.554892 [ 3830 ] {4c3ef68e-0b00-444d-99fc-a0008d1d8af5} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT L2SquaredNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT L2SquaredNorm();) 2025.03.31 19:05:38.556872 [ 3830 ] {4c3ef68e-0b00-444d-99fc-a0008d1d8af5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT L2SquaredNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.574381 [ 3830 ] {0e2312a3-715b-4f74-856b-f232fd5d211f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT LAST_DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LAST_DAY();) 2025.03.31 19:05:38.576068 [ 3830 ] {0e2312a3-715b-4f74-856b-f232fd5d211f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT LAST_DAY(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.593654 [ 3830 ] {b444c8fe-e914-40d3-8a83-6123ee855900} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT LinfDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LinfDistance();) 2025.03.31 19:05:38.595244 [ 3830 ] {b444c8fe-e914-40d3-8a83-6123ee855900} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT LinfDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.612122 [ 3830 ] {572676af-47ed-4caf-a971-ef8706485f3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT LinfNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LinfNorm();) 2025.03.31 19:05:38.613678 [ 3830 ] {572676af-47ed-4caf-a971-ef8706485f3f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT LinfNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.629976 [ 3830 ] {ce4154cd-4eb9-4691-aba6-b68e8c764540} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT LinfNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LinfNormalize();) 2025.03.31 19:05:38.631392 [ 3830 ] {ce4154cd-4eb9-4691-aba6-b68e8c764540} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT LinfNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.648105 [ 3830 ] {20eaeb2e-f706-461f-816a-0a2061795963} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT LpDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LpDistance();) 2025.03.31 19:05:38.649393 [ 3830 ] {20eaeb2e-f706-461f-816a-0a2061795963} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT LpDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.679148 [ 3830 ] {cc24f21c-fbca-4443-b8d4-0db0977ca5b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT LpNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LpNorm();) 2025.03.31 19:05:38.680389 [ 3830 ] {cc24f21c-fbca-4443-b8d4-0db0977ca5b7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT LpNorm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.699156 [ 3830 ] {0803a4e0-9a05-4429-a93b-6d76965baeca} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT LpNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT LpNormalize();) 2025.03.31 19:05:38.700861 [ 3830 ] {0803a4e0-9a05-4429-a93b-6d76965baeca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT LpNormalize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.719693 [ 3830 ] {7569e3aa-f14b-4f6a-9e8e-6b366c81f30b} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 0, should be 1: In scope SELECT MACNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MACNumToString();) 2025.03.31 19:05:38.721235 [ 3830 ] {7569e3aa-f14b-4f6a-9e8e-6b366c81f30b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 0, should be 1: In scope SELECT MACNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.739593 [ 3830 ] {e718f278-6eee-4295-a4ef-cf8919eb2eec} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 0, should be 1: In scope SELECT MACStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MACStringToNum();) 2025.03.31 19:05:38.741098 [ 3830 ] {e718f278-6eee-4295-a4ef-cf8919eb2eec} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 0, should be 1: In scope SELECT MACStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.760286 [ 3830 ] {994120a6-69f4-4fb9-9cab-625133ec1889} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 0, should be 1: In scope SELECT MACStringToOUI(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MACStringToOUI();) 2025.03.31 19:05:38.761996 [ 3830 ] {994120a6-69f4-4fb9-9cab-625133ec1889} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 0, should be 1: In scope SELECT MACStringToOUI(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.780828 [ 3830 ] {e83a3133-4819-4a1f-8968-533efa7cb89e} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT MAP_FROM_ARRAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MAP_FROM_ARRAYS();) 2025.03.31 19:05:38.791272 [ 3830 ] {e83a3133-4819-4a1f-8968-533efa7cb89e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT MAP_FROM_ARRAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.808733 [ 3830 ] {22664c3a-6120-4ffd-9ca2-55fd357c5577} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 0, should be 1: In scope SELECT MD4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MD4();) 2025.03.31 19:05:38.810635 [ 3830 ] {22664c3a-6120-4ffd-9ca2-55fd357c5577} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 0, should be 1: In scope SELECT MD4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.840830 [ 3830 ] {01866273-ec0d-4c8a-b93d-282c5120308b} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 0, should be 1: In scope SELECT MD5(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MD5();) 2025.03.31 19:05:38.842371 [ 3830 ] {01866273-ec0d-4c8a-b93d-282c5120308b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 0, should be 1: In scope SELECT MD5(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.942486 [ 3830 ] {81efc564-942e-489e-9dc2-9d8f71706427} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT MILLISECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MILLISECOND();) 2025.03.31 19:05:38.944027 [ 3830 ] {81efc564-942e-489e-9dc2-9d8f71706427} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT MILLISECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.962177 [ 3830 ] {4549514e-7156-4b8a-bfdc-d964ee8dc002} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT MINUTE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MINUTE();) 2025.03.31 19:05:38.963811 [ 3830 ] {4549514e-7156-4b8a-bfdc-d964ee8dc002} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT MINUTE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:38.980715 [ 3830 ] {6211a377-cc5b-444f-9406-7dc64a36abc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT MONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT MONTH();) 2025.03.31 19:05:38.982345 [ 3830 ] {6211a377-cc5b-444f-9406-7dc64a36abc0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT MONTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.022290 [ 3830 ] {f50ab858-8cc0-4ce9-81f5-3e43c9a217e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT OCTET_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT OCTET_LENGTH();) 2025.03.31 19:05:39.023889 [ 3830 ] {f50ab858-8cc0-4ce9-81f5-3e43c9a217e3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT OCTET_LENGTH(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.040869 [ 3830 ] {8357be5c-ed33-4631-a66d-ca4c5661f758} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT QUARTER(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT QUARTER();) 2025.03.31 19:05:39.048152 [ 3830 ] {8357be5c-ed33-4631-a66d-ca4c5661f758} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT QUARTER(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.118943 [ 3830 ] {033fcb87-c565-448e-a737-948937a9e1b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT REGEXP_EXTRACT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT REGEXP_EXTRACT();) 2025.03.31 19:05:39.120472 [ 3830 ] {033fcb87-c565-448e-a737-948937a9e1b7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT REGEXP_EXTRACT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.141411 [ 3830 ] {6d03848c-a407-44ec-b769-9962c82cb153} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT REGEXP_MATCHES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT REGEXP_MATCHES();) 2025.03.31 19:05:39.143323 [ 3830 ] {6d03848c-a407-44ec-b769-9962c82cb153} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT REGEXP_MATCHES(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.163963 [ 3830 ] {70bf26be-c148-4c82-bb43-d05978f2161a} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT REGEXP_REPLACE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT REGEXP_REPLACE();) 2025.03.31 19:05:39.165921 [ 3830 ] {70bf26be-c148-4c82-bb43-d05978f2161a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT REGEXP_REPLACE(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.228270 [ 3830 ] {721d46a5-7031-4907-8e66-0f568201917b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT SECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SECOND();) 2025.03.31 19:05:39.229644 [ 3830 ] {721d46a5-7031-4907-8e66-0f568201917b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT SECOND(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.247816 [ 3830 ] {ce139726-46f5-490b-955b-e60f2c6d38fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 0, should be 1: In scope SELECT SHA1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA1();) 2025.03.31 19:05:39.249331 [ 3830 ] {ce139726-46f5-490b-955b-e60f2c6d38fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 0, should be 1: In scope SELECT SHA1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.259092 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:39.266887 [ 3830 ] {add65bbf-7a62-4d1f-8709-61df7077fef5} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 0, should be 1: In scope SELECT SHA224(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA224();) 2025.03.31 19:05:39.268430 [ 3830 ] {add65bbf-7a62-4d1f-8709-61df7077fef5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 0, should be 1: In scope SELECT SHA224(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.286705 [ 3830 ] {523704bf-31d2-4ab7-b35b-fb3073c4b798} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 0, should be 1: In scope SELECT SHA256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA256();) 2025.03.31 19:05:39.288098 [ 3830 ] {523704bf-31d2-4ab7-b35b-fb3073c4b798} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 0, should be 1: In scope SELECT SHA256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.377131 [ 3830 ] {af5a5ee1-98e7-4a31-bc89-74933d7fa244} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 0, should be 1: In scope SELECT SHA384(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA384();) 2025.03.31 19:05:39.378790 [ 3830 ] {af5a5ee1-98e7-4a31-bc89-74933d7fa244} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 0, should be 1: In scope SELECT SHA384(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.396036 [ 3830 ] {11a4f363-dd3b-426a-92b7-84574bf6b637} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 0, should be 1: In scope SELECT SHA512(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA512();) 2025.03.31 19:05:39.397437 [ 3830 ] {11a4f363-dd3b-426a-92b7-84574bf6b637} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 0, should be 1: In scope SELECT SHA512(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.467749 [ 3830 ] {edfb8f1f-dbb9-475d-88ba-da9781494fac} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 0, should be 1: In scope SELECT SHA512_256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SHA512_256();) 2025.03.31 19:05:39.469397 [ 3830 ] {edfb8f1f-dbb9-475d-88ba-da9781494fac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 0, should be 1: In scope SELECT SHA512_256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.491478 [ 3830 ] {1e26d92c-b901-4b9a-971b-8e5f9fc63d6d} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT STD();) 2025.03.31 19:05:39.493084 [ 3830 ] {1e26d92c-b901-4b9a-971b-8e5f9fc63d6d} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.511626 [ 3830 ] {a6e3a1c2-058d-4f46-a6b9-bece609238fb} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT STDDEV_POP();) 2025.03.31 19:05:39.513188 [ 3830 ] {a6e3a1c2-058d-4f46-a6b9-bece609238fb} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.531745 [ 3830 ] {98a3b552-e325-420f-b906-19eacf151ef9} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT STDDEV_SAMP();) 2025.03.31 19:05:39.533305 [ 3830 ] {98a3b552-e325-420f-b906-19eacf151ef9} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.553298 [ 3830 ] {baf50e20-0f29-468e-8558-ac6826089e1e} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT SUBSTRING_INDEX(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SUBSTRING_INDEX();) 2025.03.31 19:05:39.555192 [ 3830 ] {baf50e20-0f29-468e-8558-ac6826089e1e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT SUBSTRING_INDEX(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.573067 [ 3830 ] {057e39e0-1498-4468-b339-3efd4e85ec25} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT SVG();) 2025.03.31 19:05:39.574714 [ 3830 ] {057e39e0-1498-4468-b339-3efd4e85ec25} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT SVG(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.644750 [ 3830 ] {70c233bc-ad89-4c9e-a96b-bde46aaf79f5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT TIMESTAMP_DIFF();) 2025.03.31 19:05:39.646882 [ 3830 ] {70c233bc-ad89-4c9e-a96b-bde46aaf79f5} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.665585 [ 3830 ] {973fc038-fb50-44ef-b9cd-56cf9afb5376} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT TO_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT TO_BASE64();) 2025.03.31 19:05:39.667301 [ 3830 ] {973fc038-fb50-44ef-b9cd-56cf9afb5376} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT TO_BASE64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.685777 [ 3830 ] {732c13ac-191a-4f33-8b9d-138e914432a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT TO_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT TO_DAYS();) 2025.03.31 19:05:39.687434 [ 3830 ] {732c13ac-191a-4f33-8b9d-138e914432a6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT TO_DAYS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.706720 [ 3830 ] {305a2dc4-77db-4d9a-b29c-f20d8c8a9012} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT TO_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT TO_UNIXTIME();) 2025.03.31 19:05:39.708442 [ 3830 ] {305a2dc4-77db-4d9a-b29c-f20d8c8a9012} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT TO_UNIXTIME(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.727539 [ 3830 ] {b0c8ce15-d877-47dc-a120-8c3556fb69bc} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ULIDStringToDateTime();) 2025.03.31 19:05:39.729073 [ 3830 ] {b0c8ce15-d877-47dc-a120-8c3556fb69bc} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function ULIDStringToDateTime: should be 1 or 2: In scope SELECT ULIDStringToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.748423 [ 3830 ] {312be526-46c4-44bc-8a67-e8df0c810fdc} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 0, should be 1 or 2.: In scope SELECT URLHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT URLHash();) 2025.03.31 19:05:39.750188 [ 3830 ] {312be526-46c4-44bc-8a67-e8df0c810fdc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHash doesn't match: passed 0, should be 1 or 2.: In scope SELECT URLHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.839187 [ 3830 ] {8538116a-ef10-403b-b858-395c541db7aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT URLHierarchy();) 2025.03.31 19:05:39.840670 [ 3830 ] {8538116a-ef10-403b-b858-395c541db7aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.858282 [ 3830 ] {f17a8b76-fd62-44d9-881d-acc657bd312b} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLPathHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT URLPathHierarchy();) 2025.03.31 19:05:39.859938 [ 3830 ] {f17a8b76-fd62-44d9-881d-acc657bd312b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 0, should be 1: In scope SELECT URLPathHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.940429 [ 3830 ] {cf2512cd-7238-4c34-885e-9acc5648e7da} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT UUIDNumToString();) 2025.03.31 19:05:39.942172 [ 3830 ] {cf2512cd-7238-4c34-885e-9acc5648e7da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDNumToString doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDNumToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.963266 [ 3830 ] {1143cbf2-7282-4741-8ede-cada7793f6e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT UUIDStringToNum();) 2025.03.31 19:05:39.965027 [ 3830 ] {1143cbf2-7282-4741-8ede-cada7793f6e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDStringToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDStringToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:39.983311 [ 3830 ] {e897436d-473a-4181-9578-a557a8dbb418} executeQuery: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT UUIDToNum();) 2025.03.31 19:05:39.985210 [ 3830 ] {e897436d-473a-4181-9578-a557a8dbb418} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UUIDToNum doesn't match: passed 0, should be 1 or 2: In scope SELECT UUIDToNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.005645 [ 3830 ] {d34552ed-e588-48dc-8319-54bc327d16a8} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT UUIDv7ToDateTime();) 2025.03.31 19:05:40.007417 [ 3830 ] {d34552ed-e588-48dc-8319-54bc327d16a8} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function UUIDv7ToDateTime: should be 1 or 2: In scope SELECT UUIDv7ToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.025839 [ 3830 ] {00067c72-d76c-4477-9745-613836a0a9c6} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT VAR_POP();) 2025.03.31 19:05:40.028275 [ 3830 ] {00067c72-d76c-4477-9745-613836a0a9c6} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.046467 [ 3830 ] {8c9f4fa8-3e60-42da-94ab-d6cbf6beddda} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT VAR_SAMP();) 2025.03.31 19:05:40.047928 [ 3830 ] {8c9f4fa8-3e60-42da-94ab-d6cbf6beddda} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.067633 [ 3830 ] {7f06154a-ed1e-42b7-b929-4e3ccbaaafbf} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT YEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT YEAR();) 2025.03.31 19:05:40.069535 [ 3830 ] {7f06154a-ed1e-42b7-b929-4e3ccbaaafbf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT YEAR(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.089484 [ 3830 ] {c230899a-92c4-41bf-b0d8-1d070ba9c174} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT YYYYMMDDToDate();) 2025.03.31 19:05:40.091419 [ 3830 ] {c230899a-92c4-41bf-b0d8-1d070ba9c174} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.110638 [ 3830 ] {3aeff1bc-c83e-4382-b825-e96fddfa97a8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT YYYYMMDDToDate32();) 2025.03.31 19:05:40.112338 [ 3830 ] {3aeff1bc-c83e-4382-b825-e96fddfa97a8} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 0 arguments: In scope SELECT YYYYMMDDToDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.164469 [ 3830 ] {9cb7780f-e206-4b5e-bcb2-45a3d3f7d283} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT YYYYMMDDhhmmssToDateTime();) 2025.03.31 19:05:40.240769 [ 3830 ] {9cb7780f-e206-4b5e-bcb2-45a3d3f7d283} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.328047 [ 3830 ] {b9127b90-75cd-44bf-a128-00f27e14d6d1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT YYYYMMDDhhmmssToDateTime64();) 2025.03.31 19:05:40.330063 [ 3830 ] {b9127b90-75cd-44bf-a128-00f27e14d6d1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDhhmmssToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT YYYYMMDDhhmmssToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.349970 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:40.350154 [ 3830 ] {4e5ed3df-1279-4555-b774-476a06d5641a} executeQuery: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 0, should be 2: In scope SELECT _CAST(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT _CAST();) 2025.03.31 19:05:40.351797 [ 3830 ] {4e5ed3df-1279-4555-b774-476a06d5641a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function _CAST doesn't match: passed 0, should be 2: In scope SELECT _CAST(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.370795 [ 3830 ] {6a2f5975-6965-4b3f-96f7-07f2d8ab9c38} executeQuery: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 0, should be 2: In scope SELECT __actionName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __actionName();) 2025.03.31 19:05:40.372540 [ 3830 ] {6a2f5975-6965-4b3f-96f7-07f2d8ab9c38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __actionName doesn't match: passed 0, should be 2: In scope SELECT __actionName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.391246 [ 3830 ] {da8846c8-0394-46d9-ad0b-12ca747ddf6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __bitBoolMaskAnd();) 2025.03.31 19:05:40.392725 [ 3830 ] {da8846c8-0394-46d9-ad0b-12ca747ddf6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskAnd doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.411188 [ 3830 ] {67a5f5d6-c923-4206-8634-29571f9c3848} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __bitBoolMaskOr();) 2025.03.31 19:05:40.413099 [ 3830 ] {67a5f5d6-c923-4206-8634-29571f9c3848} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitBoolMaskOr doesn't match: passed 0, should be 2: In scope SELECT __bitBoolMaskOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.509880 [ 3830 ] {aa0faa75-c0d0-44f3-b406-fc7bf5138aae} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 0, should be 1: In scope SELECT __bitSwapLastTwo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __bitSwapLastTwo();) 2025.03.31 19:05:40.511521 [ 3830 ] {aa0faa75-c0d0-44f3-b406-fc7bf5138aae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 0, should be 1: In scope SELECT __bitSwapLastTwo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.626331 [ 3830 ] {6dfecb5e-b3ec-4754-9086-de20c019f1fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 0, should be 1: In scope SELECT __bitWrapperFunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __bitWrapperFunc();) 2025.03.31 19:05:40.628041 [ 3830 ] {6dfecb5e-b3ec-4754-9086-de20c019f1fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 0, should be 1: In scope SELECT __bitWrapperFunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.645869 [ 3830 ] {2eeb0186-0cb5-481d-bbb3-bbad28ab40b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 0, should be 1: In scope SELECT __getScalar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __getScalar();) 2025.03.31 19:05:40.647535 [ 3830 ] {2eeb0186-0cb5-481d-bbb3-bbad28ab40b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 0, should be 1: In scope SELECT __getScalar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.665527 [ 3830 ] {4268210f-4e3e-4d5d-b432-cd3453aa742f} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 0, should be 1: In scope SELECT __scalarSubqueryResult(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT __scalarSubqueryResult();) 2025.03.31 19:05:40.667385 [ 3830 ] {4268210f-4e3e-4d5d-b432-cd3453aa742f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 0, should be 1: In scope SELECT __scalarSubqueryResult(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.685068 [ 3830 ] {5c96b35d-b64a-4c17-8ad9-a1efe1dd5c4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 0, should be 1: In scope SELECT abs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT abs();) 2025.03.31 19:05:40.686706 [ 3830 ] {5c96b35d-b64a-4c17-8ad9-a1efe1dd5c4a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 0, should be 1: In scope SELECT abs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.703686 [ 3830 ] {063640f4-19d8-4be6-b8e5-4c2ce95ec735} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 0, should be 2: In scope SELECT accurateCast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT accurateCast();) 2025.03.31 19:05:40.705124 [ 3830 ] {063640f4-19d8-4be6-b8e5-4c2ce95ec735} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCast doesn't match: passed 0, should be 2: In scope SELECT accurateCast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.802691 [ 3830 ] {16d96ffe-06ba-4468-9933-151a33890f68} executeQuery: Code: 42. DB::Exception: Function accurateCastOrDefault expected 2 or 3 arguments. Actual 0: In scope SELECT accurateCastOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT accurateCastOrDefault();) 2025.03.31 19:05:40.804163 [ 3830 ] {16d96ffe-06ba-4468-9933-151a33890f68} TCPHandler: Code: 42. DB::Exception: Function accurateCastOrDefault expected 2 or 3 arguments. Actual 0: In scope SELECT accurateCastOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.821986 [ 3830 ] {deb062a4-f3a4-41fc-8406-7f2e2ced5ee0} executeQuery: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 0, should be 2: In scope SELECT accurateCastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT accurateCastOrNull();) 2025.03.31 19:05:40.823558 [ 3830 ] {deb062a4-f3a4-41fc-8406-7f2e2ced5ee0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function accurateCastOrNull doesn't match: passed 0, should be 2: In scope SELECT accurateCastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.840950 [ 3830 ] {24c22d98-8be9-43ef-9be0-8a1828588c0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 0, should be 1: In scope SELECT acos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT acos();) 2025.03.31 19:05:40.857137 [ 3830 ] {24c22d98-8be9-43ef-9be0-8a1828588c0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 0, should be 1: In scope SELECT acos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.875289 [ 3830 ] {9a4a47f8-b3d8-4bc9-83c7-db3f3f10c2ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 0, should be 1: In scope SELECT acosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT acosh();) 2025.03.31 19:05:40.876932 [ 3830 ] {9a4a47f8-b3d8-4bc9-83c7-db3f3f10c2ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 0, should be 1: In scope SELECT acosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.895131 [ 3830 ] {6ee40ecd-46e9-461c-826b-1ca3ef5a39b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 0, should be 2: In scope SELECT addDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addDate();) 2025.03.31 19:05:40.896702 [ 3830 ] {6ee40ecd-46e9-461c-826b-1ca3ef5a39b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDate doesn't match: passed 0, should be 2: In scope SELECT addDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.913937 [ 3830 ] {25620a33-3f25-4f66-9653-11bcbafcdb2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function addDays doesn't match: passed 0, should be 2 or 3: In scope SELECT addDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addDays();) 2025.03.31 19:05:40.915537 [ 3830 ] {25620a33-3f25-4f66-9653-11bcbafcdb2e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addDays doesn't match: passed 0, should be 2 or 3: In scope SELECT addDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.932812 [ 3830 ] {bda1d95e-9a1b-4c45-a860-9e1847e40190} executeQuery: Code: 42. DB::Exception: Number of arguments for function addHours doesn't match: passed 0, should be 2 or 3: In scope SELECT addHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addHours();) 2025.03.31 19:05:40.934447 [ 3830 ] {bda1d95e-9a1b-4c45-a860-9e1847e40190} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addHours doesn't match: passed 0, should be 2 or 3: In scope SELECT addHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.953164 [ 3830 ] {f455a646-08b4-4aeb-8458-da968fc43161} executeQuery: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 0, should be 2: In scope SELECT addInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addInterval();) 2025.03.31 19:05:40.955230 [ 3830 ] {f455a646-08b4-4aeb-8458-da968fc43161} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addInterval doesn't match: passed 0, should be 2: In scope SELECT addInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.972381 [ 3830 ] {b7cdf175-4ef7-46bf-bafc-bc42cfdb513f} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addMicroseconds();) 2025.03.31 19:05:40.973997 [ 3830 ] {b7cdf175-4ef7-46bf-bafc-bc42cfdb513f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:40.989900 [ 3830 ] {78177d3e-a8ac-4945-8bbb-3ad91ebb0ee9} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addMilliseconds();) 2025.03.31 19:05:40.991262 [ 3830 ] {78177d3e-a8ac-4945-8bbb-3ad91ebb0ee9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.008325 [ 3830 ] {fe1e17b6-1a98-43b7-bb60-2fd10a29f1b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT addMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addMinutes();) 2025.03.31 19:05:41.009919 [ 3830 ] {fe1e17b6-1a98-43b7-bb60-2fd10a29f1b0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT addMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.109611 [ 3830 ] {5e07f3f3-22ac-41fb-b30f-54324bd2aa0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function addMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT addMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addMonths();) 2025.03.31 19:05:41.113045 [ 3830 ] {5e07f3f3-22ac-41fb-b30f-54324bd2aa0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT addMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.131314 [ 3830 ] {79d8b964-8c37-44e5-9590-13ba94f9a18b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addNanoseconds();) 2025.03.31 19:05:41.132807 [ 3830 ] {79d8b964-8c37-44e5-9590-13ba94f9a18b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.149864 [ 3830 ] {f3a889cc-1cb9-41b2-9e96-0484307dac50} executeQuery: Code: 42. DB::Exception: Number of arguments for function addQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT addQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addQuarters();) 2025.03.31 19:05:41.151227 [ 3830 ] {f3a889cc-1cb9-41b2-9e96-0484307dac50} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT addQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.168177 [ 3830 ] {c5eed615-44f7-41c5-8f28-121c44b16ab9} executeQuery: Code: 42. DB::Exception: Number of arguments for function addSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addSeconds();) 2025.03.31 19:05:41.169991 [ 3830 ] {c5eed615-44f7-41c5-8f28-121c44b16ab9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT addSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.188176 [ 3830 ] {337487f7-a2d9-4e1d-85c7-f14c0a2a68e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT addTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addTupleOfIntervals();) 2025.03.31 19:05:41.190116 [ 3830 ] {337487f7-a2d9-4e1d-85c7-f14c0a2a68e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT addTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.207077 [ 3830 ] {dfd4b744-21af-4f55-9d9f-56c35e7c6ae9} executeQuery: Code: 42. DB::Exception: Number of arguments for function addWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT addWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addWeeks();) 2025.03.31 19:05:41.208475 [ 3830 ] {dfd4b744-21af-4f55-9d9f-56c35e7c6ae9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT addWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.225053 [ 3830 ] {f339da1c-7a71-4f1f-8ab1-4545d291b5f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function addYears doesn't match: passed 0, should be 2 or 3: In scope SELECT addYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addYears();) 2025.03.31 19:05:41.226611 [ 3830 ] {f339da1c-7a71-4f1f-8ab1-4545d291b5f2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addYears doesn't match: passed 0, should be 2 or 3: In scope SELECT addYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.242939 [ 3830 ] {6de2f544-f8f6-41a1-9cbb-fcbef4e445d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 0, should be 1: In scope SELECT addressToLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addressToLine();) 2025.03.31 19:05:41.244414 [ 3830 ] {6de2f544-f8f6-41a1-9cbb-fcbef4e445d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 0, should be 1: In scope SELECT addressToLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.262085 [ 3830 ] {656cdc71-f3fa-43a1-9d5e-7b434b73d331} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 0, should be 1: In scope SELECT addressToLineWithInlines(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addressToLineWithInlines();) 2025.03.31 19:05:41.263531 [ 3830 ] {656cdc71-f3fa-43a1-9d5e-7b434b73d331} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 0, should be 1: In scope SELECT addressToLineWithInlines(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.280784 [ 3830 ] {c2d9fa71-f368-4695-afd2-130bb80e0ff5} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 0, should be 1: In scope SELECT addressToSymbol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT addressToSymbol();) 2025.03.31 19:05:41.282629 [ 3830 ] {c2d9fa71-f368-4695-afd2-130bb80e0ff5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 0, should be 1: In scope SELECT addressToSymbol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.314312 [ 3830 ] {2c71b789-cdcf-40e6-ac1a-509ad3e9bacd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT aes_decrypt_mysql();) 2025.03.31 19:05:41.316106 [ 3830 ] {2c71b789-cdcf-40e6-ac1a-509ad3e9bacd} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_decrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.349392 [ 3830 ] {364d5e4a-d152-42f3-95a5-45de9eb903f2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT aes_encrypt_mysql();) 2025.03.31 19:05:41.351214 [ 3830 ] {364d5e4a-d152-42f3-95a5-45de9eb903f2} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT aes_encrypt_mysql(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.368199 [ 3830 ] {c33d36f3-1de5-4e64-b404-cdefa673a34d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT age(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT age();) 2025.03.31 19:05:41.368242 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:41.369691 [ 3830 ] {c33d36f3-1de5-4e64-b404-cdefa673a34d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT age(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.395867 [ 3830 ] {588d3cd8-430e-4926-8cd7-eeb2e1fb2eaf} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT aggThrow();) 2025.03.31 19:05:41.398550 [ 3830 ] {588d3cd8-430e-4926-8cd7-eeb2e1fb2eaf} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) 2025.03.31 19:05:41.417496 [ 3830 ] {d0b9ccf0-281c-46dc-8769-c49c6501138c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT alphaTokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT alphaTokens();) 2025.03.31 19:05:41.469105 [ 3830 ] {d0b9ccf0-281c-46dc-8769-c49c6501138c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT alphaTokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.485279 [ 3830 ] {e3b5628a-f8ac-4a75-a7ab-0e694b5bcb1c} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT analysisOfVariance();) 2025.03.31 19:05:41.486749 [ 3830 ] {e3b5628a-f8ac-4a75-a7ab-0e694b5bcb1c} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.502948 [ 3830 ] {0c767e7b-de50-4b7c-b7c1-0a24a81dfb88} executeQuery: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 0: In scope SELECT and(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT and();) 2025.03.31 19:05:41.504379 [ 3830 ] {0c767e7b-de50-4b7c-b7c1-0a24a81dfb88} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "and" should be at least 2: passed 0: In scope SELECT and(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:41.521309 [ 3830 ] {051e2291-7ebe-4085-be78-50b4c28fef37} executeQuery: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT anova();) 2025.03.31 19:05:41.522876 [ 3830 ] {051e2291-7ebe-4085-be78-50b4c28fef37} TCPHandler: Code: 42. DB::Exception: Aggregate function analysisOfVariance requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.539934 [ 3830 ] {f9f81b67-1b2c-4bce-8a1d-4f3603f66fe5} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT any();) 2025.03.31 19:05:41.541422 [ 3830 ] {f9f81b67-1b2c-4bce-8a1d-4f3603f66fe5} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.557907 [ 3830 ] {8007d120-0530-457b-91da-4144ebfd6127} executeQuery: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT anyHeavy();) 2025.03.31 19:05:41.559310 [ 3830 ] {8007d120-0530-457b-91da-4144ebfd6127} TCPHandler: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.576579 [ 3830 ] {129294ca-4430-4430-a36d-1eab6a186ba2} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT anyLast();) 2025.03.31 19:05:41.578155 [ 3830 ] {129294ca-4430-4430-a36d-1eab6a186ba2} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.595158 [ 3830 ] {208268a1-7109-43d1-9398-aa1ce57c4391} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT anyLast_respect_nulls();) 2025.03.31 19:05:41.596657 [ 3830 ] {208268a1-7109-43d1-9398-aa1ce57c4391} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.613933 [ 3830 ] {10e587c5-a61e-40a1-aaed-40c6b989fdd3} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT any_respect_nulls();) 2025.03.31 19:05:41.615351 [ 3830 ] {10e587c5-a61e-40a1-aaed-40c6b989fdd3} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.676763 [ 3830 ] {9e40ff95-7f9a-44f5-8332-6ae450daad03} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT any_value();) 2025.03.31 19:05:41.678419 [ 3830 ] {9e40ff95-7f9a-44f5-8332-6ae450daad03} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.759467 [ 3830 ] {9a9c8b10-16c4-4e59-8c5e-140b5fc478ae} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT any_value_respect_nulls();) 2025.03.31 19:05:41.760966 [ 3830 ] {9a9c8b10-16c4-4e59-8c5e-140b5fc478ae} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.779143 [ 3830 ] {01f13e3f-6e57-446c-8a03-933d93996ff9} executeQuery: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 0, should be 2: In scope SELECT appendTrailingCharIfAbsent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT appendTrailingCharIfAbsent();) 2025.03.31 19:05:41.781076 [ 3830 ] {01f13e3f-6e57-446c-8a03-933d93996ff9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function appendTrailingCharIfAbsent doesn't match: passed 0, should be 2: In scope SELECT appendTrailingCharIfAbsent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.798414 [ 3830 ] {880d2782-b666-4a54-a5c5-1fd069048470} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT approx_top_count();) 2025.03.31 19:05:41.800053 [ 3830 ] {880d2782-b666-4a54-a5c5-1fd069048470} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.817461 [ 3830 ] {b8c368f9-801c-4649-b850-792c395e9241} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT approx_top_k();) 2025.03.31 19:05:41.819211 [ 3830 ] {b8c368f9-801c-4649-b850-792c395e9241} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.836615 [ 3830 ] {ff4aba34-4554-4932-8298-536faf5019ac} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT approx_top_sum();) 2025.03.31 19:05:41.838241 [ 3830 ] {ff4aba34-4554-4932-8298-536faf5019ac} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_sum requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.855149 [ 3830 ] {06d2bf36-278f-4f5f-89c9-70393c6e8053} executeQuery: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT argMax();) 2025.03.31 19:05:41.856610 [ 3830 ] {06d2bf36-278f-4f5f-89c9-70393c6e8053} TCPHandler: Code: 42. DB::Exception: Aggregate function argMax requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.873932 [ 3830 ] {e2f8becd-a4bf-4d92-8d66-17b479dc7b78} executeQuery: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT argMin();) 2025.03.31 19:05:41.875421 [ 3830 ] {e2f8becd-a4bf-4d92-8d66-17b479dc7b78} TCPHandler: Code: 42. DB::Exception: Aggregate function argMin requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.919860 [ 3830 ] {99a0e8ce-4db3-4da9-8c1a-310716519e37} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayAUC doesn't match: passed 0, should be 2: In scope SELECT arrayAUC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayAUC();) 2025.03.31 19:05:41.921459 [ 3830 ] {99a0e8ce-4db3-4da9-8c1a-310716519e37} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayAUC doesn't match: passed 0, should be 2: In scope SELECT arrayAUC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.940576 [ 3830 ] {a1b74739-245a-437b-8ab3-dc7462dc2866} executeQuery: Code: 42. DB::Exception: Function arrayAll needs at least 1 argument, passed 0: In scope SELECT arrayAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayAll();) 2025.03.31 19:05:41.942216 [ 3830 ] {a1b74739-245a-437b-8ab3-dc7462dc2866} TCPHandler: Code: 42. DB::Exception: Function arrayAll needs at least 1 argument, passed 0: In scope SELECT arrayAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.961153 [ 3830 ] {5d82ca3d-adf9-453a-91e5-de36e8eef725} executeQuery: Code: 42. DB::Exception: Function arrayAvg needs at least 1 argument, passed 0: In scope SELECT arrayAvg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayAvg();) 2025.03.31 19:05:41.963154 [ 3830 ] {5d82ca3d-adf9-453a-91e5-de36e8eef725} TCPHandler: Code: 42. DB::Exception: Function arrayAvg needs at least 1 argument, passed 0: In scope SELECT arrayAvg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.980637 [ 3830 ] {447792f0-07b0-44a4-b3a1-04402a5a219b} executeQuery: Code: 42. DB::Exception: Function arrayCompact needs at least 1 argument, passed 0: In scope SELECT arrayCompact(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayCompact();) 2025.03.31 19:05:41.982197 [ 3830 ] {447792f0-07b0-44a4-b3a1-04402a5a219b} TCPHandler: Code: 42. DB::Exception: Function arrayCompact needs at least 1 argument, passed 0: In scope SELECT arrayCompact(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:41.999636 [ 3830 ] {e86a1e66-5ece-4fe2-bc17-ccf7fddc8cfb} executeQuery: Code: 42. DB::Exception: Function arrayConcat requires at least one argument.: In scope SELECT arrayConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayConcat();) 2025.03.31 19:05:42.001066 [ 3830 ] {e86a1e66-5ece-4fe2-bc17-ccf7fddc8cfb} TCPHandler: Code: 42. DB::Exception: Function arrayConcat requires at least one argument.: In scope SELECT arrayConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.017363 [ 3830 ] {66894dd2-c64b-4077-8078-40c05ca54793} executeQuery: Code: 42. DB::Exception: Function arrayCount needs at least 1 argument, passed 0: In scope SELECT arrayCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayCount();) 2025.03.31 19:05:42.019113 [ 3830 ] {66894dd2-c64b-4077-8078-40c05ca54793} TCPHandler: Code: 42. DB::Exception: Function arrayCount needs at least 1 argument, passed 0: In scope SELECT arrayCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.035487 [ 3830 ] {0f21f152-cad8-473b-8eeb-9d68ae16c083} executeQuery: Code: 42. DB::Exception: Function arrayCumSum needs at least 1 argument, passed 0: In scope SELECT arrayCumSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayCumSum();) 2025.03.31 19:05:42.036931 [ 3830 ] {0f21f152-cad8-473b-8eeb-9d68ae16c083} TCPHandler: Code: 42. DB::Exception: Function arrayCumSum needs at least 1 argument, passed 0: In scope SELECT arrayCumSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.054523 [ 3830 ] {4c916ecc-0009-4b34-b86a-bb10f63d3b7f} executeQuery: Code: 42. DB::Exception: Function arrayCumSumNonNegative needs at least 1 argument, passed 0: In scope SELECT arrayCumSumNonNegative(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayCumSumNonNegative();) 2025.03.31 19:05:42.055931 [ 3830 ] {4c916ecc-0009-4b34-b86a-bb10f63d3b7f} TCPHandler: Code: 42. DB::Exception: Function arrayCumSumNonNegative needs at least 1 argument, passed 0: In scope SELECT arrayCumSumNonNegative(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.074614 [ 3830 ] {e55fda35-d818-44e7-8429-5292d2357c69} executeQuery: Code: 42. DB::Exception: Function arrayDifference needs at least 1 argument, passed 0: In scope SELECT arrayDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayDifference();) 2025.03.31 19:05:42.076497 [ 3830 ] {e55fda35-d818-44e7-8429-5292d2357c69} TCPHandler: Code: 42. DB::Exception: Function arrayDifference needs at least 1 argument, passed 0: In scope SELECT arrayDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.094620 [ 3830 ] {7393eb3d-aa42-425b-8604-051c962c1b87} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 0, should be 1: In scope SELECT arrayDistinct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayDistinct();) 2025.03.31 19:05:42.096337 [ 3830 ] {7393eb3d-aa42-425b-8604-051c962c1b87} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 0, should be 1: In scope SELECT arrayDistinct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.113633 [ 3830 ] {db9c85c7-57f0-498e-b956-dd8d1b92504b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 0, should be 2: In scope SELECT arrayDotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayDotProduct();) 2025.03.31 19:05:42.115356 [ 3830 ] {db9c85c7-57f0-498e-b956-dd8d1b92504b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDotProduct doesn't match: passed 0, should be 2: In scope SELECT arrayDotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.217843 [ 3830 ] {12e650a3-5886-44a7-9725-0418a0d4ba01} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 0, should be 2: In scope SELECT arrayElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayElement();) 2025.03.31 19:05:42.219251 [ 3830 ] {12e650a3-5886-44a7-9725-0418a0d4ba01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayElement doesn't match: passed 0, should be 2: In scope SELECT arrayElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.235997 [ 3830 ] {25532e21-b6c9-4562-90a1-44a323330280} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 0, should be 1: In scope SELECT arrayEnumerate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayEnumerate();) 2025.03.31 19:05:42.237678 [ 3830 ] {25532e21-b6c9-4562-90a1-44a323330280} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 0, should be 1: In scope SELECT arrayEnumerate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.254078 [ 3830 ] {2d6f3e66-7c80-4a60-9ce2-44d226007f42} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDense doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDense(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayEnumerateDense();) 2025.03.31 19:05:42.255579 [ 3830 ] {2d6f3e66-7c80-4a60-9ce2-44d226007f42} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDense doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDense(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:42.324046 [ 3830 ] {b2e14e55-7623-4fcc-b119-b5b147ed3851} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDenseRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDenseRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayEnumerateDenseRanked();) 2025.03.31 19:05:42.325530 [ 3830 ] {b2e14e55-7623-4fcc-b119-b5b147ed3851} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateDenseRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateDenseRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:42.342219 [ 3830 ] {daba0970-115d-4623-bdc5-4a01e0f2cc9c} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniq(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayEnumerateUniq();) 2025.03.31 19:05:42.343707 [ 3830 ] {daba0970-115d-4623-bdc5-4a01e0f2cc9c} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniq(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:42.360314 [ 3830 ] {24548300-c087-49b5-9d71-874c0e0ada81} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniqRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniqRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayEnumerateUniqRanked();) 2025.03.31 19:05:42.362048 [ 3830 ] {24548300-c087-49b5-9d71-874c0e0ada81} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayEnumerateUniqRanked doesn't match: passed 0, should be at least 1.: In scope SELECT arrayEnumerateUniqRanked(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:42.379789 [ 3830 ] {0ae726f0-caba-43ff-a4c5-01cea1d35383} executeQuery: Code: 42. DB::Exception: Function arrayExists needs at least 1 argument, passed 0: In scope SELECT arrayExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayExists();) 2025.03.31 19:05:42.381456 [ 3830 ] {0ae726f0-caba-43ff-a4c5-01cea1d35383} TCPHandler: Code: 42. DB::Exception: Function arrayExists needs at least 1 argument, passed 0: In scope SELECT arrayExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.391352 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:42.400291 [ 3830 ] {b170da6f-97ed-4e6d-acf6-fa1d9fe60746} executeQuery: Code: 42. DB::Exception: Function arrayFill needs at least 2 arguments, passed 0: In scope SELECT arrayFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFill();) 2025.03.31 19:05:42.402324 [ 3830 ] {b170da6f-97ed-4e6d-acf6-fa1d9fe60746} TCPHandler: Code: 42. DB::Exception: Function arrayFill needs at least 2 arguments, passed 0: In scope SELECT arrayFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.421259 [ 3830 ] {ec594e53-a415-491c-9c41-615c05f2a783} executeQuery: Code: 42. DB::Exception: Function arrayFilter needs at least 2 arguments, passed 0: In scope SELECT arrayFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFilter();) 2025.03.31 19:05:42.423283 [ 3830 ] {ec594e53-a415-491c-9c41-615c05f2a783} TCPHandler: Code: 42. DB::Exception: Function arrayFilter needs at least 2 arguments, passed 0: In scope SELECT arrayFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.443083 [ 3830 ] {6749107b-b7b6-4bc0-bf82-536a35f3a405} executeQuery: Code: 42. DB::Exception: Function arrayFirst needs at least 2 arguments, passed 0: In scope SELECT arrayFirst(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFirst();) 2025.03.31 19:05:42.444862 [ 3830 ] {6749107b-b7b6-4bc0-bf82-536a35f3a405} TCPHandler: Code: 42. DB::Exception: Function arrayFirst needs at least 2 arguments, passed 0: In scope SELECT arrayFirst(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.463539 [ 3830 ] {4f37bba2-40f2-48dd-8b8a-3611a5a66964} executeQuery: Code: 42. DB::Exception: Function arrayFirstIndex needs at least 2 arguments, passed 0: In scope SELECT arrayFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFirstIndex();) 2025.03.31 19:05:42.465166 [ 3830 ] {4f37bba2-40f2-48dd-8b8a-3611a5a66964} TCPHandler: Code: 42. DB::Exception: Function arrayFirstIndex needs at least 2 arguments, passed 0: In scope SELECT arrayFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.503352 [ 3830 ] {3d0768c5-02c1-4739-baec-36a6c31a3592} executeQuery: Code: 42. DB::Exception: Function arrayFirstOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayFirstOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFirstOrNull();) 2025.03.31 19:05:42.504846 [ 3830 ] {3d0768c5-02c1-4739-baec-36a6c31a3592} TCPHandler: Code: 42. DB::Exception: Function arrayFirstOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayFirstOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.522108 [ 3830 ] {37167224-75aa-421b-909a-30c8d414d47e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT arrayFlatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFlatten();) 2025.03.31 19:05:42.523324 [ 3830 ] {37167224-75aa-421b-909a-30c8d414d47e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT arrayFlatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.540153 [ 3830 ] {721d6d1d-6ed1-46b9-9305-fb191aa57e2c} executeQuery: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayFold();) 2025.03.31 19:05:42.542232 [ 3830 ] {721d6d1d-6ed1-46b9-9305-fb191aa57e2c} TCPHandler: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:42.559409 [ 3830 ] {e3c691a7-2bc0-468b-94c8-a285f4456f92} executeQuery: Code: 42. DB::Exception: Function arrayIntersect requires at least one argument.: In scope SELECT arrayIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayIntersect();) 2025.03.31 19:05:42.560909 [ 3830 ] {e3c691a7-2bc0-468b-94c8-a285f4456f92} TCPHandler: Code: 42. DB::Exception: Function arrayIntersect requires at least one argument.: In scope SELECT arrayIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.593455 [ 3830 ] {6e1f775b-4606-4371-868d-ffbe74aafbb0} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT arrayJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayJaccardIndex();) 2025.03.31 19:05:42.663271 [ 3830 ] {6e1f775b-4606-4371-868d-ffbe74aafbb0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT arrayJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.679599 [ 3830 ] {5db33058-ab4b-469d-bcfd-43efa844045b} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 0, should be 1: In scope SELECT arrayJoin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayJoin();) 2025.03.31 19:05:42.681057 [ 3830 ] {5db33058-ab4b-469d-bcfd-43efa844045b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 0, should be 1: In scope SELECT arrayJoin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.700140 [ 3830 ] {6b5979b7-f1bd-4fdd-b448-9b547387c963} executeQuery: Code: 42. DB::Exception: Function arrayLast needs at least 2 arguments, passed 0: In scope SELECT arrayLast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayLast();) 2025.03.31 19:05:42.702020 [ 3830 ] {6b5979b7-f1bd-4fdd-b448-9b547387c963} TCPHandler: Code: 42. DB::Exception: Function arrayLast needs at least 2 arguments, passed 0: In scope SELECT arrayLast(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.720794 [ 3830 ] {7cf9ed6e-0006-46ff-ad85-406c2deff828} executeQuery: Code: 42. DB::Exception: Function arrayLastIndex needs at least 2 arguments, passed 0: In scope SELECT arrayLastIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayLastIndex();) 2025.03.31 19:05:42.722750 [ 3830 ] {7cf9ed6e-0006-46ff-ad85-406c2deff828} TCPHandler: Code: 42. DB::Exception: Function arrayLastIndex needs at least 2 arguments, passed 0: In scope SELECT arrayLastIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.794974 [ 3830 ] {caf3c172-1fef-4b9b-844d-8c18056c3131} executeQuery: Code: 42. DB::Exception: Function arrayLastOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayLastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayLastOrNull();) 2025.03.31 19:05:42.796550 [ 3830 ] {caf3c172-1fef-4b9b-844d-8c18056c3131} TCPHandler: Code: 42. DB::Exception: Function arrayLastOrNull needs at least 2 arguments, passed 0: In scope SELECT arrayLastOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.816082 [ 3830 ] {88ac2d9a-1054-4fbf-883b-f7373e465d22} executeQuery: Code: 42. DB::Exception: Function arrayMap needs at least 2 arguments, passed 0: In scope SELECT arrayMap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayMap();) 2025.03.31 19:05:42.818048 [ 3830 ] {88ac2d9a-1054-4fbf-883b-f7373e465d22} TCPHandler: Code: 42. DB::Exception: Function arrayMap needs at least 2 arguments, passed 0: In scope SELECT arrayMap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.860872 [ 3830 ] {cf7c371b-77d5-449d-a65c-69e0f6fd057c} executeQuery: Code: 42. DB::Exception: Function arrayMax needs at least 1 argument, passed 0: In scope SELECT arrayMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayMax();) 2025.03.31 19:05:42.862602 [ 3830 ] {cf7c371b-77d5-449d-a65c-69e0f6fd057c} TCPHandler: Code: 42. DB::Exception: Function arrayMax needs at least 1 argument, passed 0: In scope SELECT arrayMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.882114 [ 3830 ] {c98f86a6-3bb3-4aa9-a2eb-b495221bac66} executeQuery: Code: 42. DB::Exception: Function arrayMin needs at least 1 argument, passed 0: In scope SELECT arrayMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayMin();) 2025.03.31 19:05:42.883956 [ 3830 ] {c98f86a6-3bb3-4aa9-a2eb-b495221bac66} TCPHandler: Code: 42. DB::Exception: Function arrayMin needs at least 1 argument, passed 0: In scope SELECT arrayMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.902727 [ 3830 ] {c941931d-50cb-4a27-91b2-78c9d9c3879c} executeQuery: Code: 42. DB::Exception: Function arrayPartialReverseSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPartialReverseSort();) 2025.03.31 19:05:42.904063 [ 3830 ] {c941931d-50cb-4a27-91b2-78c9d9c3879c} TCPHandler: Code: 42. DB::Exception: Function arrayPartialReverseSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.966786 [ 3830 ] {36b4cf39-a835-4817-bd85-3853bc1c145a} executeQuery: Code: 42. DB::Exception: Function 'arrayPartialShuffle' needs from 1 to 3 arguments, passed 0.: In scope SELECT arrayPartialShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPartialShuffle();) 2025.03.31 19:05:42.968197 [ 3830 ] {36b4cf39-a835-4817-bd85-3853bc1c145a} TCPHandler: Code: 42. DB::Exception: Function 'arrayPartialShuffle' needs from 1 to 3 arguments, passed 0.: In scope SELECT arrayPartialShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:42.985540 [ 3830 ] {867ddb3e-a203-42d7-8354-4a7c00fb9ca2} executeQuery: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPartialSort();) 2025.03.31 19:05:42.987463 [ 3830 ] {867ddb3e-a203-42d7-8354-4a7c00fb9ca2} TCPHandler: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 0: In scope SELECT arrayPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.005283 [ 3830 ] {2706dfa0-280d-4cc9-b5b7-ca667dc85556} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 0, should be 1: In scope SELECT arrayPopBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPopBack();) 2025.03.31 19:05:43.007083 [ 3830 ] {2706dfa0-280d-4cc9-b5b7-ca667dc85556} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 0, should be 1: In scope SELECT arrayPopBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.025286 [ 3830 ] {8e38d011-cfb8-4abd-968d-09ae6e6e701d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 0, should be 1: In scope SELECT arrayPopFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPopFront();) 2025.03.31 19:05:43.026941 [ 3830 ] {8e38d011-cfb8-4abd-968d-09ae6e6e701d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 0, should be 1: In scope SELECT arrayPopFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.178289 [ 3830 ] {b7c41fae-0470-4ec0-b7a6-f3895ff5c774} executeQuery: Code: 42. DB::Exception: Function arrayProduct needs at least 1 argument, passed 0: In scope SELECT arrayProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayProduct();) 2025.03.31 19:05:43.179829 [ 3830 ] {b7c41fae-0470-4ec0-b7a6-f3895ff5c774} TCPHandler: Code: 42. DB::Exception: Function arrayProduct needs at least 1 argument, passed 0: In scope SELECT arrayProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.197958 [ 3830 ] {11557c63-7ae7-4047-a890-8535b605a5fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 0, should be 2: In scope SELECT arrayPushBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPushBack();) 2025.03.31 19:05:43.199405 [ 3830 ] {11557c63-7ae7-4047-a890-8535b605a5fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushBack doesn't match: passed 0, should be 2: In scope SELECT arrayPushBack(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.221390 [ 3830 ] {4ef5b3d9-d2e0-4ddd-a337-a52e4b8f6b43} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 0, should be 2: In scope SELECT arrayPushFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayPushFront();) 2025.03.31 19:05:43.223232 [ 3830 ] {4ef5b3d9-d2e0-4ddd-a337-a52e4b8f6b43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPushFront doesn't match: passed 0, should be 2: In scope SELECT arrayPushFront(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.243717 [ 3830 ] {df9fc41a-377d-4e36-98a3-13ee31d5013d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 0, should be 2: In scope SELECT arrayRandomSample(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayRandomSample();) 2025.03.31 19:05:43.245401 [ 3830 ] {df9fc41a-377d-4e36-98a3-13ee31d5013d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRandomSample doesn't match: passed 0, should be 2: In scope SELECT arrayRandomSample(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.263384 [ 3830 ] {d92451ad-4386-4d6a-a11f-1ed0a8608047} executeQuery: Code: 35. DB::Exception: Number of arguments for function arrayReduce doesn't match: passed 0, should be at least 2.: In scope SELECT arrayReduce(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReduce();) 2025.03.31 19:05:43.264817 [ 3830 ] {d92451ad-4386-4d6a-a11f-1ed0a8608047} TCPHandler: Code: 35. DB::Exception: Number of arguments for function arrayReduce doesn't match: passed 0, should be at least 2.: In scope SELECT arrayReduce(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:43.282368 [ 3830 ] {9b1ceeb0-f01b-4d18-875b-e235e5fa688c} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 0, should be at least 3.: In scope SELECT arrayReduceInRanges(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReduceInRanges();) 2025.03.31 19:05:43.283968 [ 3830 ] {9b1ceeb0-f01b-4d18-875b-e235e5fa688c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 0, should be at least 3.: In scope SELECT arrayReduceInRanges(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.302651 [ 3830 ] {5fb9368b-493e-4b12-8c99-e76e52927e1a} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayResize doesn't match: passed 0, should be 2 or 3: In scope SELECT arrayResize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayResize();) 2025.03.31 19:05:43.304171 [ 3830 ] {5fb9368b-493e-4b12-8c99-e76e52927e1a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayResize doesn't match: passed 0, should be 2 or 3: In scope SELECT arrayResize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.322754 [ 3830 ] {d1e11997-9586-443a-ac05-abc8007fe8c5} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 0, should be 1: In scope SELECT arrayReverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReverse();) 2025.03.31 19:05:43.324333 [ 3830 ] {d1e11997-9586-443a-ac05-abc8007fe8c5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 0, should be 1: In scope SELECT arrayReverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.344874 [ 3830 ] {868d93a7-8b63-4f8e-9324-fe994555b023} executeQuery: Code: 42. DB::Exception: Function arrayReverseFill needs at least 2 arguments, passed 0: In scope SELECT arrayReverseFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReverseFill();) 2025.03.31 19:05:43.350201 [ 3830 ] {868d93a7-8b63-4f8e-9324-fe994555b023} TCPHandler: Code: 42. DB::Exception: Function arrayReverseFill needs at least 2 arguments, passed 0: In scope SELECT arrayReverseFill(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.368917 [ 3830 ] {c0052f12-4a9d-4195-b3fa-7304c1380977} executeQuery: Code: 42. DB::Exception: Function arrayReverseSort needs at least 1 argument, passed 0: In scope SELECT arrayReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReverseSort();) 2025.03.31 19:05:43.370770 [ 3830 ] {c0052f12-4a9d-4195-b3fa-7304c1380977} TCPHandler: Code: 42. DB::Exception: Function arrayReverseSort needs at least 1 argument, passed 0: In scope SELECT arrayReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.388033 [ 3830 ] {f13240b0-ca28-4a9b-98c3-9308456b9166} executeQuery: Code: 42. DB::Exception: Function arrayReverseSplit needs at least 2 arguments, passed 0: In scope SELECT arrayReverseSplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayReverseSplit();) 2025.03.31 19:05:43.389619 [ 3830 ] {f13240b0-ca28-4a9b-98c3-9308456b9166} TCPHandler: Code: 42. DB::Exception: Function arrayReverseSplit needs at least 2 arguments, passed 0: In scope SELECT arrayReverseSplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.409677 [ 3830 ] {d777385b-83b4-41ec-82a0-7dce3bf52222} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 0, should be 2: In scope SELECT arrayRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayRotateLeft();) 2025.03.31 19:05:43.411661 [ 3830 ] {d777385b-83b4-41ec-82a0-7dce3bf52222} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateLeft doesn't match: passed 0, should be 2: In scope SELECT arrayRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.431582 [ 3830 ] {d16e0df3-3bb6-4ece-904f-6c4cdc7ee990} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 0, should be 2: In scope SELECT arrayRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayRotateRight();) 2025.03.31 19:05:43.435613 [ 3830 ] {d16e0df3-3bb6-4ece-904f-6c4cdc7ee990} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayRotateRight doesn't match: passed 0, should be 2: In scope SELECT arrayRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.495348 [ 3830 ] {98fa1e73-2f42-4870-bf45-c8e8ae6abbdf} executeQuery: Code: 42. DB::Exception: Function arrayShiftLeft requires at least two arguments.: In scope SELECT arrayShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayShiftLeft();) 2025.03.31 19:05:43.497059 [ 3830 ] {98fa1e73-2f42-4870-bf45-c8e8ae6abbdf} TCPHandler: Code: 42. DB::Exception: Function arrayShiftLeft requires at least two arguments.: In scope SELECT arrayShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.515024 [ 3830 ] {595e91b0-8cc5-4fbe-a304-0a7bfbca5536} executeQuery: Code: 42. DB::Exception: Function arrayShiftRight requires at least two arguments.: In scope SELECT arrayShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayShiftRight();) 2025.03.31 19:05:43.516566 [ 3830 ] {595e91b0-8cc5-4fbe-a304-0a7bfbca5536} TCPHandler: Code: 42. DB::Exception: Function arrayShiftRight requires at least two arguments.: In scope SELECT arrayShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.530592 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:43.533267 [ 3830 ] {95aa39f4-59cd-45da-aebf-316a39f39aa6} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 0, should be 2: In scope SELECT arrayShingles(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayShingles();) 2025.03.31 19:05:43.534847 [ 3830 ] {95aa39f4-59cd-45da-aebf-316a39f39aa6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayShingles doesn't match: passed 0, should be 2: In scope SELECT arrayShingles(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.572705 [ 3830 ] {73b6a8f6-3bea-4074-b187-eda810414e40} executeQuery: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 0.: In scope SELECT arrayShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayShuffle();) 2025.03.31 19:05:43.574705 [ 3830 ] {73b6a8f6-3bea-4074-b187-eda810414e40} TCPHandler: Code: 42. DB::Exception: Function 'arrayShuffle' needs from 1 to 2 arguments, passed 0.: In scope SELECT arrayShuffle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.612781 [ 3830 ] {4233404a-4c06-4469-940b-2e0c2103fd20} executeQuery: Code: 42. DB::Exception: Number of arguments for function arraySlice doesn't match: passed 0, should be 2 or 3: In scope SELECT arraySlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arraySlice();) 2025.03.31 19:05:43.614922 [ 3830 ] {4233404a-4c06-4469-940b-2e0c2103fd20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arraySlice doesn't match: passed 0, should be 2 or 3: In scope SELECT arraySlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.680015 [ 3830 ] {b634a97b-0cd4-44dc-8b72-3039cc31c9ce} executeQuery: Code: 42. DB::Exception: Function arraySort needs at least 1 argument, passed 0: In scope SELECT arraySort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arraySort();) 2025.03.31 19:05:43.682256 [ 3830 ] {b634a97b-0cd4-44dc-8b72-3039cc31c9ce} TCPHandler: Code: 42. DB::Exception: Function arraySort needs at least 1 argument, passed 0: In scope SELECT arraySort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.701326 [ 3830 ] {160d8d77-e112-4f86-b3cf-bed2e4b91629} executeQuery: Code: 42. DB::Exception: Function arraySplit needs at least 2 arguments, passed 0: In scope SELECT arraySplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arraySplit();) 2025.03.31 19:05:43.703184 [ 3830 ] {160d8d77-e112-4f86-b3cf-bed2e4b91629} TCPHandler: Code: 42. DB::Exception: Function arraySplit needs at least 2 arguments, passed 0: In scope SELECT arraySplit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.721438 [ 3830 ] {a6f51572-4899-4caf-bccf-6d1b29db3450} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT arrayStringConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayStringConcat();) 2025.03.31 19:05:43.723209 [ 3830 ] {a6f51572-4899-4caf-bccf-6d1b29db3450} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'arrayStringConcat'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT arrayStringConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.740932 [ 3830 ] {ba455b52-7701-4b65-a14b-8152d8fed58c} executeQuery: Code: 42. DB::Exception: Function arraySum needs at least 1 argument, passed 0: In scope SELECT arraySum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arraySum();) 2025.03.31 19:05:43.742986 [ 3830 ] {ba455b52-7701-4b65-a14b-8152d8fed58c} TCPHandler: Code: 42. DB::Exception: Function arraySum needs at least 1 argument, passed 0: In scope SELECT arraySum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.760816 [ 3830 ] {b9959664-a6f8-445e-a44a-e1397792d12f} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayUniq(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayUniq();) 2025.03.31 19:05:43.762423 [ 3830 ] {b9959664-a6f8-445e-a44a-e1397792d12f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayUniq doesn't match: passed 0, should be at least 1.: In scope SELECT arrayUniq(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.780825 [ 3830 ] {85f020ec-23bf-4610-9ad9-846d9ad393ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 0, should be 2: In scope SELECT arrayWithConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayWithConstant();) 2025.03.31 19:05:43.782497 [ 3830 ] {85f020ec-23bf-4610-9ad9-846d9ad393ed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayWithConstant doesn't match: passed 0, should be 2: In scope SELECT arrayWithConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.800769 [ 3830 ] {774947c2-ef59-4b00-abc7-4957224ec2c2} executeQuery: Code: 35. DB::Exception: Function arrayZip needs at least one argument; passed 0.: In scope SELECT arrayZip(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT arrayZip();) 2025.03.31 19:05:43.802673 [ 3830 ] {774947c2-ef59-4b00-abc7-4957224ec2c2} TCPHandler: Code: 35. DB::Exception: Function arrayZip needs at least one argument; passed 0.: In scope SELECT arrayZip(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:43.846945 [ 3830 ] {f5330147-1425-42f8-8b42-d5c2ed628ff6} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT array_agg();) 2025.03.31 19:05:43.849126 [ 3830 ] {f5330147-1425-42f8-8b42-d5c2ed628ff6} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.899940 [ 3830 ] {d1fdc805-4a75-43e7-9897-405893a4b9a4} executeQuery: Code: 35. DB::Exception: Array aggregate functions require at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT array_concat_agg();) 2025.03.31 19:05:43.901975 [ 3830 ] {d1fdc805-4a75-43e7-9897-405893a4b9a4} TCPHandler: Code: 35. DB::Exception: Array aggregate functions require at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:43.922708 [ 3830 ] {4b9a6f83-758c-45f3-b3ed-2887f4c6f8c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 0, should be 1: In scope SELECT ascii(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ascii();) 2025.03.31 19:05:43.924667 [ 3830 ] {4b9a6f83-758c-45f3-b3ed-2887f4c6f8c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 0, should be 1: In scope SELECT ascii(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:43.980460 [ 3830 ] {35a01f62-425e-4f3d-9dc2-15c0df8b59aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 0, should be 1: In scope SELECT asin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT asin();) 2025.03.31 19:05:43.982298 [ 3830 ] {35a01f62-425e-4f3d-9dc2-15c0df8b59aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 0, should be 1: In scope SELECT asin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.000670 [ 3830 ] {e74a64aa-61e2-4f9c-ab25-501a11fa87c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 0, should be 1: In scope SELECT asinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT asinh();) 2025.03.31 19:05:44.002561 [ 3830 ] {e74a64aa-61e2-4f9c-ab25-501a11fa87c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 0, should be 1: In scope SELECT asinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.113409 [ 3830 ] {093821fe-f4cc-4f77-80f8-3b14bc35d496} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 0, should be 1: In scope SELECT assumeNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT assumeNotNull();) 2025.03.31 19:05:44.115411 [ 3830 ] {093821fe-f4cc-4f77-80f8-3b14bc35d496} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 0, should be 1: In scope SELECT assumeNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.134220 [ 3830 ] {42a77237-d189-42c8-9754-65818ab07e70} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 0, should be 1: In scope SELECT atan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT atan();) 2025.03.31 19:05:44.135760 [ 3830 ] {42a77237-d189-42c8-9754-65818ab07e70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 0, should be 1: In scope SELECT atan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.154119 [ 3830 ] {26130acf-2448-4233-8d69-625f360f16ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 0, should be 2: In scope SELECT atan2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT atan2();) 2025.03.31 19:05:44.155884 [ 3830 ] {26130acf-2448-4233-8d69-625f360f16ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan2 doesn't match: passed 0, should be 2: In scope SELECT atan2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.254059 [ 3830 ] {109e945a-0369-48b0-8ba9-074c72abd3bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 0, should be 1: In scope SELECT atanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT atanh();) 2025.03.31 19:05:44.255545 [ 3830 ] {109e945a-0369-48b0-8ba9-074c72abd3bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 0, should be 1: In scope SELECT atanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.274877 [ 3830 ] {3ee9d497-06f1-4aea-9b58-65f9a99daf99} executeQuery: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT avg();) 2025.03.31 19:05:44.276761 [ 3830 ] {3ee9d497-06f1-4aea-9b58-65f9a99daf99} TCPHandler: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.295573 [ 3830 ] {43b05afd-361a-480a-8e1b-a1644501df4b} executeQuery: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT avgWeighted();) 2025.03.31 19:05:44.297008 [ 3830 ] {43b05afd-361a-480a-8e1b-a1644501df4b} TCPHandler: Code: 42. DB::Exception: Aggregate function avgWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.367603 [ 3830 ] {7e8ab2e1-a7fb-435b-aaf1-987b7e5ad3e1} executeQuery: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 0.: In scope SELECT bar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bar();) 2025.03.31 19:05:44.369336 [ 3830 ] {7e8ab2e1-a7fb-435b-aaf1-987b7e5ad3e1} TCPHandler: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 0.: In scope SELECT bar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.386954 [ 3830 ] {89489c52-de29-4465-a7af-e2011e665a30} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 0, should be 1: In scope SELECT base58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base58Decode();) 2025.03.31 19:05:44.388510 [ 3830 ] {89489c52-de29-4465-a7af-e2011e665a30} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 0, should be 1: In scope SELECT base58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.405194 [ 3830 ] {02cb6197-c0c1-4cfa-aa78-f957b4a2a530} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 0, should be 1: In scope SELECT base58Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base58Encode();) 2025.03.31 19:05:44.407147 [ 3830 ] {02cb6197-c0c1-4cfa-aa78-f957b4a2a530} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 0, should be 1: In scope SELECT base58Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.424395 [ 3830 ] {21adba4f-dc43-436b-9acf-e40c38dd9466} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT base64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base64Decode();) 2025.03.31 19:05:44.425939 [ 3830 ] {21adba4f-dc43-436b-9acf-e40c38dd9466} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 0, should be 1: In scope SELECT base64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.443086 [ 3830 ] {42f1baed-cd28-4768-b542-47369b630a89} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT base64Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base64Encode();) 2025.03.31 19:05:44.444621 [ 3830 ] {42f1baed-cd28-4768-b542-47369b630a89} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 0, should be 1: In scope SELECT base64Encode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.460408 [ 3830 ] {c62793ae-2502-49fc-977c-2499871c6486} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base64URLDecode();) 2025.03.31 19:05:44.461934 [ 3830 ] {c62793ae-2502-49fc-977c-2499871c6486} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 0, should be 1: In scope SELECT base64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.479000 [ 3830 ] {4b7fb3b1-6be7-48fa-8cbd-cf02f2598b15} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT base64URLEncode();) 2025.03.31 19:05:44.480653 [ 3830 ] {4b7fb3b1-6be7-48fa-8cbd-cf02f2598b15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 0, should be 1: In scope SELECT base64URLEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.497122 [ 3830 ] {a80941de-a517-4766-a662-749175a4f93c} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 0, should be 1: In scope SELECT basename(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT basename();) 2025.03.31 19:05:44.498756 [ 3830 ] {a80941de-a517-4766-a662-749175a4f93c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 0, should be 1: In scope SELECT basename(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.516366 [ 3830 ] {1ea457d0-ce5e-4be9-bb91-d7f3669372b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 0, should be 1: In scope SELECT bin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bin();) 2025.03.31 19:05:44.518055 [ 3830 ] {1ea457d0-ce5e-4be9-bb91-d7f3669372b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 0, should be 1: In scope SELECT bin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.534155 [ 3830 ] {edc6da9c-0582-4ebc-88ef-3dc9d94c883f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 0, should be 2: In scope SELECT bitAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitAnd();) 2025.03.31 19:05:44.535623 [ 3830 ] {edc6da9c-0582-4ebc-88ef-3dc9d94c883f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitAnd doesn't match: passed 0, should be 2: In scope SELECT bitAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.554649 [ 3830 ] {375c2fc9-3997-42f5-9ead-bcc0388ee177} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 0, should be 1: In scope SELECT bitCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitCount();) 2025.03.31 19:05:44.556245 [ 3830 ] {375c2fc9-3997-42f5-9ead-bcc0388ee177} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 0, should be 1: In scope SELECT bitCount(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.563431 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:44.572314 [ 3830 ] {29d195da-a762-4e30-b69e-263f58a09ec7} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 0, should be 2: In scope SELECT bitHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitHammingDistance();) 2025.03.31 19:05:44.575140 [ 3830 ] {29d195da-a762-4e30-b69e-263f58a09ec7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitHammingDistance doesn't match: passed 0, should be 2: In scope SELECT bitHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.590418 [ 3830 ] {8f66054f-ad9d-480e-adfa-6c9aa08385e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 0, should be 1: In scope SELECT bitNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitNot();) 2025.03.31 19:05:44.591947 [ 3830 ] {8f66054f-ad9d-480e-adfa-6c9aa08385e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 0, should be 1: In scope SELECT bitNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.608747 [ 3830 ] {eb9b536f-82c3-4d73-8ddd-31d0ec7b05d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 0, should be 2: In scope SELECT bitOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitOr();) 2025.03.31 19:05:44.610293 [ 3830 ] {eb9b536f-82c3-4d73-8ddd-31d0ec7b05d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitOr doesn't match: passed 0, should be 2: In scope SELECT bitOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.678446 [ 3830 ] {b1936f54-37c2-4345-862d-71087b68b03e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 0, should be 1: In scope SELECT bitPositionsToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitPositionsToArray();) 2025.03.31 19:05:44.679894 [ 3830 ] {b1936f54-37c2-4345-862d-71087b68b03e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 0, should be 1: In scope SELECT bitPositionsToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.697231 [ 3830 ] {bb196ff4-05a8-44d6-891b-8a7fe064a253} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 0, should be 2: In scope SELECT bitRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitRotateLeft();) 2025.03.31 19:05:44.699062 [ 3830 ] {bb196ff4-05a8-44d6-891b-8a7fe064a253} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateLeft doesn't match: passed 0, should be 2: In scope SELECT bitRotateLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.716473 [ 3830 ] {708aa97f-c044-4e07-80ab-0ae842b5d9a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 0, should be 2: In scope SELECT bitRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitRotateRight();) 2025.03.31 19:05:44.718139 [ 3830 ] {708aa97f-c044-4e07-80ab-0ae842b5d9a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitRotateRight doesn't match: passed 0, should be 2: In scope SELECT bitRotateRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.735954 [ 3830 ] {584b5c64-10a1-4418-94bd-51c5ee73ceaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 0, should be 2: In scope SELECT bitShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitShiftLeft();) 2025.03.31 19:05:44.737418 [ 3830 ] {584b5c64-10a1-4418-94bd-51c5ee73ceaa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftLeft doesn't match: passed 0, should be 2: In scope SELECT bitShiftLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.754851 [ 3830 ] {cee909bc-5927-41d3-bf39-fe6a9712a599} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 0, should be 2: In scope SELECT bitShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitShiftRight();) 2025.03.31 19:05:44.756206 [ 3830 ] {cee909bc-5927-41d3-bf39-fe6a9712a599} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitShiftRight doesn't match: passed 0, should be 2: In scope SELECT bitShiftRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.863524 [ 3830 ] {ff46228d-9c63-404b-ab89-409a35cd4416} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT bitSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitSlice();) 2025.03.31 19:05:44.865009 [ 3830 ] {ff46228d-9c63-404b-ab89-409a35cd4416} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'bitSlice'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT bitSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.881132 [ 3830 ] {5b00695d-e957-4de7-af84-bd5767aa94ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 0, should be 2: In scope SELECT bitTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitTest();) 2025.03.31 19:05:44.882726 [ 3830 ] {5b00695d-e957-4de7-af84-bd5767aa94ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitTest doesn't match: passed 0, should be 2: In scope SELECT bitTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:44.900570 [ 3830 ] {d67e8ee6-dbda-4793-a06c-e0def2fc0772} executeQuery: Code: 35. DB::Exception: Number of arguments for function bitTestAll doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAll(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitTestAll();) 2025.03.31 19:05:44.902283 [ 3830 ] {d67e8ee6-dbda-4793-a06c-e0def2fc0772} TCPHandler: Code: 35. DB::Exception: Number of arguments for function bitTestAll doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAll(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:44.920427 [ 3830 ] {910d4797-3d3f-4094-bc00-b8eb2f1e8a94} executeQuery: Code: 35. DB::Exception: Number of arguments for function bitTestAny doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAny(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitTestAny();) 2025.03.31 19:05:44.922385 [ 3830 ] {910d4797-3d3f-4094-bc00-b8eb2f1e8a94} TCPHandler: Code: 35. DB::Exception: Number of arguments for function bitTestAny doesn't match: passed 0, should be at least 2.: In scope SELECT bitTestAny(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:44.991752 [ 3830 ] {aa9f3968-39b3-45d0-bebf-683fc974931b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 0, should be 2: In scope SELECT bitXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitXor();) 2025.03.31 19:05:44.993260 [ 3830 ] {aa9f3968-39b3-45d0-bebf-683fc974931b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitXor doesn't match: passed 0, should be 2: In scope SELECT bitXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.110033 [ 3830 ] {4a5bcee0-6512-4bfd-8e05-13832c068835} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 0, should be 2: In scope SELECT bitmapAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapAnd();) 2025.03.31 19:05:45.111563 [ 3830 ] {4a5bcee0-6512-4bfd-8e05-13832c068835} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAnd doesn't match: passed 0, should be 2: In scope SELECT bitmapAnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.129413 [ 3830 ] {2847a0c0-cafb-4ae2-9f1b-29989eff026e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapAndCardinality();) 2025.03.31 19:05:45.130895 [ 3830 ] {2847a0c0-cafb-4ae2-9f1b-29989eff026e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.149078 [ 3830 ] {9a07a1a4-6985-4180-bd43-12821f182b05} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapAndnot();) 2025.03.31 19:05:45.150785 [ 3830 ] {9a07a1a4-6985-4180-bd43-12821f182b05} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnot doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.167033 [ 3830 ] {083c844a-aaf6-4f1f-b824-deafcd35a927} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnotCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapAndnotCardinality();) 2025.03.31 19:05:45.168422 [ 3830 ] {083c844a-aaf6-4f1f-b824-deafcd35a927} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapAndnotCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapAndnotCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.185209 [ 3830 ] {a4a88132-9f3c-4052-9831-dc142a515185} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 0, should be 1: In scope SELECT bitmapBuild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapBuild();) 2025.03.31 19:05:45.186899 [ 3830 ] {a4a88132-9f3c-4052-9831-dc142a515185} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 0, should be 1: In scope SELECT bitmapBuild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.202874 [ 3830 ] {2ae94882-30e1-4f23-90f3-3091bbbc2eb3} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 0, should be 1: In scope SELECT bitmapCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapCardinality();) 2025.03.31 19:05:45.205464 [ 3830 ] {2ae94882-30e1-4f23-90f3-3091bbbc2eb3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 0, should be 1: In scope SELECT bitmapCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.220530 [ 3830 ] {25bae0d1-6c83-4c07-bfe4-d8ddbf39ae76} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 0, should be 2: In scope SELECT bitmapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapContains();) 2025.03.31 19:05:45.222080 [ 3830 ] {25bae0d1-6c83-4c07-bfe4-d8ddbf39ae76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapContains doesn't match: passed 0, should be 2: In scope SELECT bitmapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.240155 [ 3830 ] {82905525-78b4-4b80-8a5c-7e16ce8d95d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapHasAll();) 2025.03.31 19:05:45.241874 [ 3830 ] {82905525-78b4-4b80-8a5c-7e16ce8d95d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAll doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.258253 [ 3830 ] {05fedc34-4848-412e-9ee8-a9dbbd0be87f} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapHasAny();) 2025.03.31 19:05:45.259715 [ 3830 ] {05fedc34-4848-412e-9ee8-a9dbbd0be87f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapHasAny doesn't match: passed 0, should be 2: In scope SELECT bitmapHasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.278618 [ 3830 ] {39f3b0bd-5074-46d1-a434-ba4396be8a2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 0, should be 1: In scope SELECT bitmapMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapMax();) 2025.03.31 19:05:45.280162 [ 3830 ] {39f3b0bd-5074-46d1-a434-ba4396be8a2e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 0, should be 1: In scope SELECT bitmapMax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.441545 [ 3830 ] {b017a921-f053-43d3-9de6-c2730194df73} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 0, should be 1: In scope SELECT bitmapMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapMin();) 2025.03.31 19:05:45.443160 [ 3830 ] {b017a921-f053-43d3-9de6-c2730194df73} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 0, should be 1: In scope SELECT bitmapMin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.471312 [ 3830 ] {97200eac-c1ee-422e-8c3c-df6816b50555} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 0, should be 2: In scope SELECT bitmapOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapOr();) 2025.03.31 19:05:45.472647 [ 3830 ] {97200eac-c1ee-422e-8c3c-df6816b50555} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOr doesn't match: passed 0, should be 2: In scope SELECT bitmapOr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.489600 [ 3830 ] {5254e851-a642-466c-bdc1-86ca818212be} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapOrCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapOrCardinality();) 2025.03.31 19:05:45.491544 [ 3830 ] {5254e851-a642-466c-bdc1-86ca818212be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapOrCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapOrCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.565987 [ 3830 ] {f607964f-77ad-457e-869b-b3a819c2384b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapSubsetInRange();) 2025.03.31 19:05:45.567455 [ 3830 ] {f607964f-77ad-457e-869b-b3a819c2384b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.585983 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:45.593204 [ 3830 ] {7ae52ca4-b37e-4ff9-9023-53849c5b1f5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetLimit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapSubsetLimit();) 2025.03.31 19:05:45.595437 [ 3830 ] {7ae52ca4-b37e-4ff9-9023-53849c5b1f5e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 0, should be 3: In scope SELECT bitmapSubsetLimit(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.612276 [ 3830 ] {81fa787a-5265-4108-8d08-0621c226a36a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 0, should be 1: In scope SELECT bitmapToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapToArray();) 2025.03.31 19:05:45.613690 [ 3830 ] {81fa787a-5265-4108-8d08-0621c226a36a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 0, should be 1: In scope SELECT bitmapToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.629993 [ 3830 ] {71470744-6fc6-4cb5-9f7b-668adaec737c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 0, should be 3: In scope SELECT bitmapTransform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapTransform();) 2025.03.31 19:05:45.631432 [ 3830 ] {71470744-6fc6-4cb5-9f7b-668adaec737c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 0, should be 3: In scope SELECT bitmapTransform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.650275 [ 3830 ] {253be15c-f456-406f-a3d4-c82954c01855} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 0, should be 2: In scope SELECT bitmapXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapXor();) 2025.03.31 19:05:45.651873 [ 3830 ] {253be15c-f456-406f-a3d4-c82954c01855} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXor doesn't match: passed 0, should be 2: In scope SELECT bitmapXor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.726528 [ 3830 ] {bae68339-b832-410f-9006-42a2da28fb8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapXorCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmapXorCardinality();) 2025.03.31 19:05:45.728087 [ 3830 ] {bae68339-b832-410f-9006-42a2da28fb8c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapXorCardinality doesn't match: passed 0, should be 2: In scope SELECT bitmapXorCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.838628 [ 3830 ] {319765a4-77ce-4e81-91bb-17ec8e6ab615} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 0, should be 1: In scope SELECT bitmaskToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmaskToArray();) 2025.03.31 19:05:45.840129 [ 3830 ] {319765a4-77ce-4e81-91bb-17ec8e6ab615} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 0, should be 1: In scope SELECT bitmaskToArray(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:45.911455 [ 3830 ] {d2132f23-67d6-4391-aa2f-108765ec1efb} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 0, should be 1: In scope SELECT bitmaskToList(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT bitmaskToList();) 2025.03.31 19:05:45.912994 [ 3830 ] {d2132f23-67d6-4391-aa2f-108765ec1efb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 0, should be 1: In scope SELECT bitmaskToList(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.138801 [ 3830 ] {4561881a-f398-4690-b799-9abbd20ba921} executeQuery: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT boundingRatio();) 2025.03.31 19:05:46.140754 [ 3830 ] {4561881a-f398-4690-b799-9abbd20ba921} TCPHandler: Code: 42. DB::Exception: Aggregate function boundingRatio requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.185423 [ 3830 ] {dd02acaf-86f2-475e-86d8-f7854c185fe8} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT byteHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT byteHammingDistance();) 2025.03.31 19:05:46.219459 [ 3830 ] {dd02acaf-86f2-475e-86d8-f7854c185fe8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT byteHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.262405 [ 3830 ] {0c7ac982-e114-439b-91e9-4dcee3d3b601} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT byteSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT byteSlice();) 2025.03.31 19:05:46.263837 [ 3830 ] {0c7ac982-e114-439b-91e9-4dcee3d3b601} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT byteSlice(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.283656 [ 3830 ] {4b83b68e-dd0e-45c9-9d2e-caec9b66b51d} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT byteSwap();) 2025.03.31 19:05:46.285258 [ 3830 ] {4b83b68e-dd0e-45c9-9d2e-caec9b66b51d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.305599 [ 3830 ] {3ac34f2a-e7ac-4640-8400-8fd3b8346cbd} executeQuery: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpr(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT caseWithExpr();) 2025.03.31 19:05:46.307219 [ 3830 ] {3ac34f2a-e7ac-4640-8400-8fd3b8346cbd} TCPHandler: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpr(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:46.325088 [ 3830 ] {13a3b136-4739-4e27-b028-0a91fbac973f} executeQuery: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpression(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT caseWithExpression();) 2025.03.31 19:05:46.326749 [ 3830 ] {13a3b136-4739-4e27-b028-0a91fbac973f} TCPHandler: Code: 35. DB::Exception: Function caseWithExpression expects at least 1 arguments: In scope SELECT caseWithExpression(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:46.343973 [ 3830 ] {bc2dcf31-b148-4e08-ae0e-1e5cc222579e} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT caseWithoutExpr();) 2025.03.31 19:05:46.345851 [ 3830 ] {bc2dcf31-b148-4e08-ae0e-1e5cc222579e} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.363712 [ 3830 ] {ac14b375-2fce-4e80-9b7d-10d6d8776961} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT caseWithoutExpression();) 2025.03.31 19:05:46.365461 [ 3830 ] {ac14b375-2fce-4e80-9b7d-10d6d8776961} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.476090 [ 3830 ] {7e923604-4213-484e-aca5-3e807e751aee} executeQuery: Code: 35. DB::Exception: Function catboostEvaluate expects at least 2 arguments: In scope SELECT catboostEvaluate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT catboostEvaluate();) 2025.03.31 19:05:46.477914 [ 3830 ] {7e923604-4213-484e-aca5-3e807e751aee} TCPHandler: Code: 35. DB::Exception: Function catboostEvaluate expects at least 2 arguments: In scope SELECT catboostEvaluate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:46.585418 [ 3830 ] {ee124119-929f-4e34-8609-617eec530e0c} executeQuery: Code: 42. DB::Exception: Aggregate function categoricalInformationValue requires two or more arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT categoricalInformationValue();) 2025.03.31 19:05:46.587311 [ 3830 ] {ee124119-929f-4e34-8609-617eec530e0c} TCPHandler: Code: 42. DB::Exception: Aggregate function categoricalInformationValue requires two or more arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.604569 [ 3830 ] {661aed9e-5db1-402e-be9f-2df697e0a65c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 0, should be 1: In scope SELECT cbrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cbrt();) 2025.03.31 19:05:46.663795 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:46.672835 [ 3830 ] {661aed9e-5db1-402e-be9f-2df697e0a65c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 0, should be 1: In scope SELECT cbrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.775178 [ 3830 ] {b76713d1-cb43-47ff-8e9b-7603f7d081fd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceil(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ceil();) 2025.03.31 19:05:46.776858 [ 3830 ] {b76713d1-cb43-47ff-8e9b-7603f7d081fd} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceil(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.794032 [ 3830 ] {35377400-8593-4c62-a55d-b5c208350532} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceiling(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ceiling();) 2025.03.31 19:05:46.795422 [ 3830 ] {35377400-8593-4c62-a55d-b5c208350532} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'ceil'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT ceiling(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.815031 [ 3830 ] {e67ae34e-93e7-4ade-b0bd-69988162dea4} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 0, should be 2: In scope SELECT changeDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeDay();) 2025.03.31 19:05:46.816844 [ 3830 ] {e67ae34e-93e7-4ade-b0bd-69988162dea4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeDay doesn't match: passed 0, should be 2: In scope SELECT changeDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.833229 [ 3830 ] {42fc562e-601a-415d-a6ea-b0ff362deccc} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 0, should be 2: In scope SELECT changeHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeHour();) 2025.03.31 19:05:46.834976 [ 3830 ] {42fc562e-601a-415d-a6ea-b0ff362deccc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeHour doesn't match: passed 0, should be 2: In scope SELECT changeHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.924105 [ 3830 ] {d273c89f-61e4-4fbb-a808-5d3eeb1cf03b} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 0, should be 2: In scope SELECT changeMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeMinute();) 2025.03.31 19:05:46.926018 [ 3830 ] {d273c89f-61e4-4fbb-a808-5d3eeb1cf03b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMinute doesn't match: passed 0, should be 2: In scope SELECT changeMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.942207 [ 3830 ] {fad35d2b-93f0-4e17-a83c-c0befebab066} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 0, should be 2: In scope SELECT changeMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeMonth();) 2025.03.31 19:05:46.943653 [ 3830 ] {fad35d2b-93f0-4e17-a83c-c0befebab066} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeMonth doesn't match: passed 0, should be 2: In scope SELECT changeMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.961305 [ 3830 ] {08eb2362-dd34-47df-bb85-e38dbc58d393} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 0, should be 2: In scope SELECT changeSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeSecond();) 2025.03.31 19:05:46.962995 [ 3830 ] {08eb2362-dd34-47df-bb85-e38dbc58d393} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeSecond doesn't match: passed 0, should be 2: In scope SELECT changeSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:46.982567 [ 3830 ] {b82d3aab-f29d-42f8-900f-e0a5021afda5} executeQuery: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 0, should be 2: In scope SELECT changeYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT changeYear();) 2025.03.31 19:05:46.984178 [ 3830 ] {b82d3aab-f29d-42f8-900f-e0a5021afda5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function changeYear doesn't match: passed 0, should be 2: In scope SELECT changeYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.004148 [ 3830 ] {d53bccf1-e3d1-484c-9f3d-ea5f4dde5b8b} executeQuery: Code: 35. DB::Exception: Number of arguments for function char can't be 0, should be at least 1: In scope SELECT char(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT char();) 2025.03.31 19:05:47.006149 [ 3830 ] {d53bccf1-e3d1-484c-9f3d-ea5f4dde5b8b} TCPHandler: Code: 35. DB::Exception: Number of arguments for function char can't be 0, should be at least 1: In scope SELECT char(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:47.050725 [ 3830 ] {2036c6e3-1e31-4f14-b3a8-fdd770adb86f} executeQuery: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 0, should be 3: In scope SELECT clamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT clamp();) 2025.03.31 19:05:47.052136 [ 3830 ] {2036c6e3-1e31-4f14-b3a8-fdd770adb86f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 0, should be 3: In scope SELECT clamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.156116 [ 3830 ] {52ccb968-be02-4666-8270-8b64adfd9e67} executeQuery: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparator(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT concatWithSeparator();) 2025.03.31 19:05:47.158032 [ 3830 ] {52ccb968-be02-4666-8270-8b64adfd9e67} TCPHandler: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparator(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.175484 [ 3830 ] {bfd8ab9b-f265-4a49-92f1-2f0cf21bedd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function concatWithSeparatorAssumeInjective doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparatorAssumeInjective(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT concatWithSeparatorAssumeInjective();) 2025.03.31 19:05:47.177084 [ 3830 ] {bfd8ab9b-f265-4a49-92f1-2f0cf21bedd9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function concatWithSeparatorAssumeInjective doesn't match: passed 0, should be at least 1: In scope SELECT concatWithSeparatorAssumeInjective(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.194248 [ 3830 ] {81409aad-b5e3-43ef-a6cc-1dd749e57886} executeQuery: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concat_ws(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT concat_ws();) 2025.03.31 19:05:47.196015 [ 3830 ] {81409aad-b5e3-43ef-a6cc-1dd749e57886} TCPHandler: Code: 42. DB::Exception: Number of arguments for function concatWithSeparator doesn't match: passed 0, should be at least 1: In scope SELECT concat_ws(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.332184 [ 3830 ] {5c71b5ff-abce-45b5-a5f1-0a2a17d2bcd3} executeQuery: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT contingency();) 2025.03.31 19:05:47.333839 [ 3830 ] {5c71b5ff-abce-45b5-a5f1-0a2a17d2bcd3} TCPHandler: Code: 42. DB::Exception: Aggregate function contingency requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.352944 [ 3830 ] {3b61f17e-8fb7-443a-a52d-a90dfabec6f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 0, should be 3: In scope SELECT convertCharset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT convertCharset();) 2025.03.31 19:05:47.355111 [ 3830 ] {3b61f17e-8fb7-443a-a52d-a90dfabec6f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 0, should be 3: In scope SELECT convertCharset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.373650 [ 3830 ] {79884ba7-fbb3-4ee4-894c-cba6c76dbba4} executeQuery: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT corr();) 2025.03.31 19:05:47.375587 [ 3830 ] {79884ba7-fbb3-4ee4-894c-cba6c76dbba4} TCPHandler: Code: 42. DB::Exception: Aggregate function corr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.549496 [ 3830 ] {aba96e81-5b18-41b6-ab92-b1b305f508e9} executeQuery: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT corrStable();) 2025.03.31 19:05:47.553364 [ 3830 ] {aba96e81-5b18-41b6-ab92-b1b305f508e9} TCPHandler: Code: 42. DB::Exception: Aggregate function corrStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.663646 [ 3830 ] {b429d519-1ca2-41cd-adcc-51fb21b2b31d} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 0, should be 1: In scope SELECT cos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cos();) 2025.03.31 19:05:47.665200 [ 3830 ] {b429d519-1ca2-41cd-adcc-51fb21b2b31d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 0, should be 1: In scope SELECT cos(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.682671 [ 3830 ] {23d5fe14-0194-418c-b2db-7dce824ce4e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 0, should be 1: In scope SELECT cosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cosh();) 2025.03.31 19:05:47.684208 [ 3830 ] {23d5fe14-0194-418c-b2db-7dce824ce4e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 0, should be 1: In scope SELECT cosh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.703169 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:47.703473 [ 3830 ] {dc2240a3-1729-4176-ad6f-df318f7dddaf} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 0, should be 2: In scope SELECT cosineDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cosineDistance();) 2025.03.31 19:05:47.705396 [ 3830 ] {dc2240a3-1729-4176-ad6f-df318f7dddaf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosineDistance doesn't match: passed 0, should be 2: In scope SELECT cosineDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.847105 [ 3830 ] {54ab79db-0e8e-45f7-a4b2-3c3e3412250a} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 0, should be 1: In scope SELECT countDigits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countDigits();) 2025.03.31 19:05:47.848622 [ 3830 ] {54ab79db-0e8e-45f7-a4b2-3c3e3412250a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 0, should be 1: In scope SELECT countDigits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.866563 [ 3830 ] {054ecf03-c396-4246-bbd1-d2b0e9f2c6c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 0, should be 2: In scope SELECT countEqual(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countEqual();) 2025.03.31 19:05:47.868416 [ 3830 ] {054ecf03-c396-4246-bbd1-d2b0e9f2c6c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countEqual doesn't match: passed 0, should be 2: In scope SELECT countEqual(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.885550 [ 3830 ] {99213b6e-c193-4ce1-84f5-358bb034b14e} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 0, should be 2: In scope SELECT countMatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countMatches();) 2025.03.31 19:05:47.888117 [ 3830 ] {99213b6e-c193-4ce1-84f5-358bb034b14e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatches doesn't match: passed 0, should be 2: In scope SELECT countMatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.906172 [ 3830 ] {881c121a-97d0-4921-af17-77ead7aa22a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT countMatchesCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countMatchesCaseInsensitive();) 2025.03.31 19:05:47.907817 [ 3830 ] {881c121a-97d0-4921-af17-77ead7aa22a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countMatchesCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT countMatchesCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.926192 [ 3830 ] {8208b36c-67b8-4586-8c95-9f1e4a66b6e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstrings doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstrings(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countSubstrings();) 2025.03.31 19:05:47.928095 [ 3830 ] {8208b36c-67b8-4586-8c95-9f1e4a66b6e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstrings doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstrings(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.944531 [ 3830 ] {5de877d3-27b0-414d-a2a4-9841452fc952} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countSubstringsCaseInsensitive();) 2025.03.31 19:05:47.946341 [ 3830 ] {5de877d3-27b0-414d-a2a4-9841452fc952} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.964653 [ 3830 ] {f5ba2cda-6986-4b16-9cda-5350b689660a} executeQuery: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT countSubstringsCaseInsensitiveUTF8();) 2025.03.31 19:05:47.966497 [ 3830 ] {f5ba2cda-6986-4b16-9cda-5350b689660a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countSubstringsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT countSubstringsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:47.985089 [ 3830 ] {6f0fc2f9-5264-44f0-827a-c7e51897a3b9} executeQuery: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT covarPop();) 2025.03.31 19:05:47.986810 [ 3830 ] {6f0fc2f9-5264-44f0-827a-c7e51897a3b9} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPop requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.016342 [ 3830 ] {b9c25800-71b0-489f-b48b-0c2cd3dc2a28} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT covarPopMatrix();) 2025.03.31 19:05:48.019067 [ 3830 ] {b9c25800-71b0-489f-b48b-0c2cd3dc2a28} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) 2025.03.31 19:05:48.048757 [ 3830 ] {d3c4da4e-2c05-4a96-8f82-8b42c108ac64} executeQuery: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT covarPopStable();) 2025.03.31 19:05:48.050502 [ 3830 ] {d3c4da4e-2c05-4a96-8f82-8b42c108ac64} TCPHandler: Code: 42. DB::Exception: Aggregate function covarPopStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.066430 [ 3830 ] {4ddecee4-89e5-4a3b-acd2-0822f68cec53} executeQuery: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT covarSamp();) 2025.03.31 19:05:48.067944 [ 3830 ] {4ddecee4-89e5-4a3b-acd2-0822f68cec53} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.207806 [ 3830 ] {9d0862fb-6946-46b9-9dbb-accaab539285} executeQuery: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT covarSampStable();) 2025.03.31 19:05:48.209252 [ 3830 ] {9d0862fb-6946-46b9-9dbb-accaab539285} TCPHandler: Code: 42. DB::Exception: Aggregate function covarSampStable requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.225163 [ 3830 ] {225f0c8b-9c40-417f-a43b-5daf8444e4f0} executeQuery: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cramersV();) 2025.03.31 19:05:48.226746 [ 3830 ] {225f0c8b-9c40-417f-a43b-5daf8444e4f0} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersV requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.243089 [ 3830 ] {6103a9f9-3df2-4f17-a2c5-91eb3c688d40} executeQuery: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cramersVBiasCorrected();) 2025.03.31 19:05:48.244542 [ 3830 ] {6103a9f9-3df2-4f17-a2c5-91eb3c688d40} TCPHandler: Code: 42. DB::Exception: Aggregate function cramersVBiasCorrected requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.378412 [ 3830 ] {3e6dfa33-8064-4cd0-89b6-5c261e83740d} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT currentSchemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT currentSchemas();) 2025.03.31 19:05:48.379941 [ 3830 ] {3e6dfa33-8064-4cd0-89b6-5c261e83740d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT currentSchemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.551434 [ 3830 ] {bf11e68d-b84b-4cd4-86f2-5f578c1cb50b} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT current_schemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT current_schemas();) 2025.03.31 19:05:48.553215 [ 3830 ] {bf11e68d-b84b-4cd4-86f2-5f578c1cb50b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 0, should be 1: In scope SELECT current_schemas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.724125 [ 3830 ] {bf8ba6e1-da5c-4188-85a7-5ebeb9893b06} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 0, should be 1: In scope SELECT cutFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutFragment();) 2025.03.31 19:05:48.725645 [ 3830 ] {bf8ba6e1-da5c-4188-85a7-5ebeb9893b06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 0, should be 1: In scope SELECT cutFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.732360 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:48.743290 [ 3830 ] {30019da2-d1ae-4173-9a89-a00b0e0f7ecc} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 0, should be 3: In scope SELECT cutIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutIPv6();) 2025.03.31 19:05:48.744966 [ 3830 ] {30019da2-d1ae-4173-9a89-a00b0e0f7ecc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 0, should be 3: In scope SELECT cutIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.762003 [ 3830 ] {efc838e1-2bf4-4fda-9e79-f708b6fc6cef} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 0, should be 1: In scope SELECT cutQueryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutQueryString();) 2025.03.31 19:05:48.763471 [ 3830 ] {efc838e1-2bf4-4fda-9e79-f708b6fc6cef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 0, should be 1: In scope SELECT cutQueryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.778796 [ 3830 ] {d63e5b79-d65b-44cd-852f-610caba4bb40} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT cutQueryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutQueryStringAndFragment();) 2025.03.31 19:05:48.780263 [ 3830 ] {d63e5b79-d65b-44cd-852f-610caba4bb40} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT cutQueryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.908472 [ 3830 ] {1ff21e97-5ea4-4aef-a8a9-9420935e1241} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomain();) 2025.03.31 19:05:48.910303 [ 3830 ] {1ff21e97-5ea4-4aef-a8a9-9420935e1241} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.925651 [ 3830 ] {6d5be32a-fa64-44dc-bf12-02531df5089d} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainCustom();) 2025.03.31 19:05:48.927106 [ 3830 ] {6d5be32a-fa64-44dc-bf12-02531df5089d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.941673 [ 3830 ] {3ccf0e30-3a49-459a-af6c-7135d4a8ad16} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC();) 2025.03.31 19:05:48.942856 [ 3830 ] {3ccf0e30-3a49-459a-af6c-7135d4a8ad16} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.957145 [ 3830 ] {61d2f487-901f-4ba5-aa66-550779a4239b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW();) 2025.03.31 19:05:48.958471 [ 3830 ] {61d2f487-901f-4ba5-aa66-550779a4239b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWW doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.980036 [ 3830 ] {474ce526-a30a-482a-9c04-73ed045b74a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC();) 2025.03.31 19:05:48.981908 [ 3830 ] {474ce526-a30a-482a-9c04-73ed045b74a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainCustomWithWWWRFC doesn't match: passed 0, should be 2: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:48.999664 [ 3830 ] {c8bb2ff1-9bcd-4a44-9d37-f574b6d1f459} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainRFC();) 2025.03.31 19:05:49.003633 [ 3830 ] {c8bb2ff1-9bcd-4a44-9d37-f574b6d1f459} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.020763 [ 3830 ] {b2731050-ed57-4153-b528-bab42248335f} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWW();) 2025.03.31 19:05:49.022460 [ 3830 ] {b2731050-ed57-4153-b528-bab42248335f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.040700 [ 3830 ] {6fe1f497-26f7-4d30-8e05-b3cf5f40b31b} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC();) 2025.03.31 19:05:49.042715 [ 3830 ] {6fe1f497-26f7-4d30-8e05-b3cf5f40b31b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 0, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.059111 [ 3830 ] {4ae34b58-408a-4330-8545-869b1d59818e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 0, should be 2: In scope SELECT cutURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutURLParameter();) 2025.03.31 19:05:49.060734 [ 3830 ] {4ae34b58-408a-4330-8545-869b1d59818e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutURLParameter doesn't match: passed 0, should be 2: In scope SELECT cutURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.080917 [ 3830 ] {a1fb1c9a-2859-4821-b11b-7391b77d7939} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 0, should be 1: In scope SELECT cutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT cutWWW();) 2025.03.31 19:05:49.083040 [ 3830 ] {a1fb1c9a-2859-4821-b11b-7391b77d7939} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 0, should be 1: In scope SELECT cutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.101203 [ 3830 ] {2a0a5389-0c9e-49b5-b91e-825e8af8bc16} executeQuery: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 0, should be 2: In scope SELECT damerauLevenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT damerauLevenshteinDistance();) 2025.03.31 19:05:49.103190 [ 3830 ] {2a0a5389-0c9e-49b5-b91e-825e8af8bc16} TCPHandler: Code: 42. DB::Exception: Number of arguments for function damerauLevenshteinDistance doesn't match: passed 0, should be 2: In scope SELECT damerauLevenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.119531 [ 3830 ] {f22fe444-bb90-4037-b270-24c9a9f6ff41} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateDiff();) 2025.03.31 19:05:49.121019 [ 3830 ] {f22fe444-bb90-4037-b270-24c9a9f6ff41} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.137550 [ 3830 ] {049c6c64-0c71-44bc-9079-7d29c87b392b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateName doesn't match: passed 0: In scope SELECT dateName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateName();) 2025.03.31 19:05:49.139160 [ 3830 ] {049c6c64-0c71-44bc-9079-7d29c87b392b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateName doesn't match: passed 0: In scope SELECT dateName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.154594 [ 3830 ] {22f6a74e-285e-45b1-ba5e-d34df99bd0c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateTime64ToSnowflake();) 2025.03.31 19:05:49.156029 [ 3830 ] {22f6a74e-285e-45b1-ba5e-d34df99bd0c6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.286949 [ 3830 ] {ef4e14e8-e8de-4a00-8138-8dcb554c8960} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTime64ToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateTime64ToSnowflakeID();) 2025.03.31 19:05:49.288472 [ 3830 ] {ef4e14e8-e8de-4a00-8138-8dcb554c8960} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTime64ToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTime64ToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.303540 [ 3830 ] {a5f0c1f2-2b6a-43cc-880c-89c76a2aa9b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateTimeToSnowflake();) 2025.03.31 19:05:49.304958 [ 3830 ] {a5f0c1f2-2b6a-43cc-880c-89c76a2aa9b6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.324157 [ 3830 ] {ef184927-db7c-4e9e-acc5-8ed387527a92} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTimeToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateTimeToSnowflakeID();) 2025.03.31 19:05:49.326070 [ 3830 ] {ef184927-db7c-4e9e-acc5-8ed387527a92} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateTimeToSnowflakeID'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT dateTimeToSnowflakeID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.354655 [ 3830 ] {40511ee9-0680-45b8-8824-ac3abbf1fcfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT dateTrunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dateTrunc();) 2025.03.31 19:05:49.356399 [ 3830 ] {40511ee9-0680-45b8-8824-ac3abbf1fcfd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTrunc doesn't match: passed 0, should be 2 or 3: In scope SELECT dateTrunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.386819 [ 3830 ] {6ef8143a-2130-47cf-bc70-9f15bc95cb48} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT date_diff();) 2025.03.31 19:05:49.388327 [ 3830 ] {6ef8143a-2130-47cf-bc70-9f15bc95cb48} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.406795 [ 3830 ] {2f2c2933-4a40-4917-a734-d29912a9567e} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeHTMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT decodeHTMLComponent();) 2025.03.31 19:05:49.408234 [ 3830 ] {2f2c2933-4a40-4917-a734-d29912a9567e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeHTMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.423650 [ 3830 ] {321ddead-73a1-48f2-a47f-2840d0575a20} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT decodeURLComponent();) 2025.03.31 19:05:49.425067 [ 3830 ] {321ddead-73a1-48f2-a47f-2840d0575a20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.442126 [ 3830 ] {7abc94dc-1b02-400d-8c0d-1a0126562efe} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT decodeURLFormComponent();) 2025.03.31 19:05:49.443774 [ 3830 ] {7abc94dc-1b02-400d-8c0d-1a0126562efe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT decodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.459765 [ 3830 ] {6345503e-89d7-4c7d-8002-de1718e08638} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT decodeXMLComponent();) 2025.03.31 19:05:49.461279 [ 3830 ] {6345503e-89d7-4c7d-8002-de1718e08638} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT decodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.539839 [ 3830 ] {728046ec-a1ac-4ca4-8b24-f9d0d6fd64d4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT decrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT decrypt();) 2025.03.31 19:05:49.541549 [ 3830 ] {728046ec-a1ac-4ca4-8b24-f9d0d6fd64d4} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT decrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.765881 [ 3830 ] {106aff1e-813a-44c3-b13e-8a6f6a018b62} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfArgumentType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT defaultValueOfArgumentType();) 2025.03.31 19:05:49.767328 [ 3830 ] {106aff1e-813a-44c3-b13e-8a6f6a018b62} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfArgumentType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.784213 [ 3830 ] {cf4a5fca-0348-4212-b2b5-e41c5d61835a} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT defaultValueOfTypeName();) 2025.03.31 19:05:49.785616 [ 3830 ] {cf4a5fca-0348-4212-b2b5-e41c5d61835a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 0, should be 1: In scope SELECT defaultValueOfTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.802415 [ 3830 ] {63a32d6b-18a5-4269-b5ba-cbcff7a32c07} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 0, should be 1: In scope SELECT degrees(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT degrees();) 2025.03.31 19:05:49.803864 [ 3830 ] {63a32d6b-18a5-4269-b5ba-cbcff7a32c07} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 0, should be 1: In scope SELECT degrees(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.821009 [ 3830 ] {e685556f-f408-401e-b2f6-0de0ef8ad36f} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT deltaSum();) 2025.03.31 19:05:49.822890 [ 3830 ] {e685556f-f408-401e-b2f6-0de0ef8ad36f} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.839597 [ 3830 ] {9cff831f-2003-4949-95b0-6db7f6c8b941} executeQuery: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT deltaSumTimestamp();) 2025.03.31 19:05:49.841324 [ 3830 ] {9cff831f-2003-4949-95b0-6db7f6c8b941} TCPHandler: Code: 42. DB::Exception: Aggregate function deltaSumTimestamp requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.859704 [ 3830 ] {650fd777-dbdf-49d8-874e-04b569b1bf1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 0, should be 1: In scope SELECT demangle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT demangle();) 2025.03.31 19:05:49.861414 [ 3830 ] {650fd777-dbdf-49d8-874e-04b569b1bf1f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 0, should be 1: In scope SELECT demangle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:49.868904 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:49.911842 [ 3830 ] {56421963-5b89-411d-963f-2bddef9c54a8} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT denseRank();) 2025.03.31 19:05:49.914230 [ 3830 ] {56421963-5b89-411d-963f-2bddef9c54a8} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.03.31 19:05:50.028497 [ 3830 ] {146321bd-57da-4f4e-b9c2-941637f2056e} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dense_rank();) 2025.03.31 19:05:50.030527 [ 3830 ] {146321bd-57da-4f4e-b9c2-941637f2056e} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.03.31 19:05:50.049392 [ 3830 ] {68ffc2ef-80ca-4888-93d0-8334834187e1} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectCharset();) 2025.03.31 19:05:50.051046 [ 3830 ] {68ffc2ef-80ca-4888-93d0-8334834187e1} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:05:50.070117 [ 3830 ] {954d1e18-b0fa-4d7b-a62f-0b1e92742dee} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectLanguage();) 2025.03.31 19:05:50.071520 [ 3830 ] {954d1e18-b0fa-4d7b-a62f-0b1e92742dee} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:05:50.089312 [ 3830 ] {cbef5220-5395-4951-bdc2-51275e65d8e0} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectLanguageMixed();) 2025.03.31 19:05:50.090619 [ 3830 ] {cbef5220-5395-4951-bdc2-51275e65d8e0} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:05:50.110166 [ 3830 ] {e752d240-e66e-4df2-9df2-37e0e2e62fb4} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectLanguageUnknown();) 2025.03.31 19:05:50.111821 [ 3830 ] {e752d240-e66e-4df2-9df2-37e0e2e62fb4} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:05:50.129128 [ 3830 ] {2f526a61-23a2-4523-8b66-01c66273acb8} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectProgrammingLanguage();) 2025.03.31 19:05:50.130853 [ 3830 ] {2f526a61-23a2-4523-8b66-01c66273acb8} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:05:50.149289 [ 3830 ] {9345fb3b-8f14-4f8d-9eb7-49bce0090606} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT detectTonality();) 2025.03.31 19:05:50.218225 [ 3830 ] {9345fb3b-8f14-4f8d-9eb7-49bce0090606} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:05:50.236009 [ 3830 ] {eb31de92-4f1b-4e7e-8fae-d91d64c0c3ec} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGet();) 2025.03.31 19:05:50.237611 [ 3830 ] {eb31de92-4f1b-4e7e-8fae-d91d64c0c3ec} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.254263 [ 3830 ] {ca857e66-1826-4889-879e-16ef5a3ec269} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetAll();) 2025.03.31 19:05:50.255786 [ 3830 ] {ca857e66-1826-4889-879e-16ef5a3ec269} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.271628 [ 3830 ] {f94bfb42-3859-432b-b05a-f2c8080c54f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 0, should be 2: In scope SELECT dictGetChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetChildren();) 2025.03.31 19:05:50.273012 [ 3830 ] {f94bfb42-3859-432b-b05a-f2c8080c54f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetChildren doesn't match: passed 0, should be 2: In scope SELECT dictGetChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.385050 [ 3830 ] {3105422c-d3cd-4a9f-920f-c8784bf7d65c} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetDate();) 2025.03.31 19:05:50.386799 [ 3830 ] {3105422c-d3cd-4a9f-920f-c8784bf7d65c} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.404203 [ 3830 ] {c7c84084-f79f-4f41-93b8-d33f049c4654} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetDateOrDefault();) 2025.03.31 19:05:50.405675 [ 3830 ] {c7c84084-f79f-4f41-93b8-d33f049c4654} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.422322 [ 3830 ] {add72b6b-bf18-4452-bf20-2c8ff74b8b93} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetDateTime();) 2025.03.31 19:05:50.423840 [ 3830 ] {add72b6b-bf18-4452-bf20-2c8ff74b8b93} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.441296 [ 3830 ] {a2d60a15-2371-44a9-b8ad-01b8d66d84f4} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetDateTimeOrDefault();) 2025.03.31 19:05:50.443140 [ 3830 ] {a2d60a15-2371-44a9-b8ad-01b8d66d84f4} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.461268 [ 3830 ] {53e91438-f9cb-4487-bdea-633599badbba} executeQuery: Code: 42. DB::Exception: Illegal arguments size of function dictGetDescendants. Expects 2 or 3 arguments size. Actual size 0: In scope SELECT dictGetDescendants(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetDescendants();) 2025.03.31 19:05:50.463302 [ 3830 ] {53e91438-f9cb-4487-bdea-633599badbba} TCPHandler: Code: 42. DB::Exception: Illegal arguments size of function dictGetDescendants. Expects 2 or 3 arguments size. Actual size 0: In scope SELECT dictGetDescendants(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.480731 [ 3830 ] {2ae6ac1e-9569-48e8-a3fa-9835f2b0a79d} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetFloat32();) 2025.03.31 19:05:50.482635 [ 3830 ] {2ae6ac1e-9569-48e8-a3fa-9835f2b0a79d} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.538136 [ 3830 ] {f03a78f8-e596-4e70-9bdc-eeb47dc07615} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetFloat32OrDefault();) 2025.03.31 19:05:50.539833 [ 3830 ] {f03a78f8-e596-4e70-9bdc-eeb47dc07615} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.558198 [ 3830 ] {1a04cdfe-c243-4f93-b405-1938e85dccaa} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetFloat64();) 2025.03.31 19:05:50.559824 [ 3830 ] {1a04cdfe-c243-4f93-b405-1938e85dccaa} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.578616 [ 3830 ] {dee6c931-6b13-4046-bea8-0c06acb1e45e} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetFloat64OrDefault();) 2025.03.31 19:05:50.580382 [ 3830 ] {dee6c931-6b13-4046-bea8-0c06acb1e45e} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.659898 [ 3830 ] {2cadd085-2eb5-4389-a625-24ef09fd3965} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 0, should be 2: In scope SELECT dictGetHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetHierarchy();) 2025.03.31 19:05:50.662095 [ 3830 ] {2cadd085-2eb5-4389-a625-24ef09fd3965} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetHierarchy doesn't match: passed 0, should be 2: In scope SELECT dictGetHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.711029 [ 3830 ] {c1f63abe-42d9-4298-8e6b-2c83b2100db7} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetIPv4();) 2025.03.31 19:05:50.712877 [ 3830 ] {c1f63abe-42d9-4298-8e6b-2c83b2100db7} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.733059 [ 3830 ] {537188b4-eab5-4e08-a4ca-afb8a5134c54} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetIPv4OrDefault();) 2025.03.31 19:05:50.735079 [ 3830 ] {537188b4-eab5-4e08-a4ca-afb8a5134c54} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.754236 [ 3830 ] {93cff860-2bdd-4c01-9088-0b62eadd457a} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetIPv6();) 2025.03.31 19:05:50.755741 [ 3830 ] {93cff860-2bdd-4c01-9088-0b62eadd457a} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.774716 [ 3830 ] {e47f0390-7a07-4b33-99a7-5a78019df8c4} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetIPv6OrDefault();) 2025.03.31 19:05:50.776411 [ 3830 ] {e47f0390-7a07-4b33-99a7-5a78019df8c4} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.795125 [ 3830 ] {38f801d6-fddc-46ec-b0ea-b27944a238d7} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt16();) 2025.03.31 19:05:50.796850 [ 3830 ] {38f801d6-fddc-46ec-b0ea-b27944a238d7} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.887413 [ 3830 ] {af030bdc-4211-4b6f-bbf9-305a4a031618} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt16OrDefault();) 2025.03.31 19:05:50.889168 [ 3830 ] {af030bdc-4211-4b6f-bbf9-305a4a031618} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.906704 [ 3830 ] {0c2671b3-6b06-4e30-8e44-a770e1d996a6} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt32();) 2025.03.31 19:05:50.912419 [ 3830 ] {0c2671b3-6b06-4e30-8e44-a770e1d996a6} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.931008 [ 3830 ] {b437ffea-b4d8-40bb-b4be-282fca213bd3} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt32OrDefault();) 2025.03.31 19:05:50.932602 [ 3830 ] {b437ffea-b4d8-40bb-b4be-282fca213bd3} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.949204 [ 3830 ] {74668927-9257-4aae-9070-5b62bb14d1af} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt64();) 2025.03.31 19:05:50.950909 [ 3830 ] {74668927-9257-4aae-9070-5b62bb14d1af} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.968867 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:50.968998 [ 3830 ] {0fd2a57e-fb32-4ef3-a024-7399bb227a6a} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt64OrDefault();) 2025.03.31 19:05:50.970690 [ 3830 ] {0fd2a57e-fb32-4ef3-a024-7399bb227a6a} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:50.987378 [ 3830 ] {08b300f5-e4ed-4ec5-86d3-a580a81abff9} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt8();) 2025.03.31 19:05:50.988891 [ 3830 ] {08b300f5-e4ed-4ec5-86d3-a580a81abff9} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.066693 [ 3830 ] {800eb92c-6b49-49d5-b200-816966d4ee9e} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetInt8OrDefault();) 2025.03.31 19:05:51.068173 [ 3830 ] {800eb92c-6b49-49d5-b200-816966d4ee9e} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.084824 [ 3830 ] {ec724278-8ef4-4805-a24c-194b2dc87753} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetOrDefault();) 2025.03.31 19:05:51.086464 [ 3830 ] {ec724278-8ef4-4805-a24c-194b2dc87753} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.104530 [ 3830 ] {af628d2a-11ea-47e6-bc1a-ee86603bd966} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetOrNull();) 2025.03.31 19:05:51.106417 [ 3830 ] {af628d2a-11ea-47e6-bc1a-ee86603bd966} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.122823 [ 3830 ] {23d82648-d219-4c29-95ac-dee06eb63f20} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetString();) 2025.03.31 19:05:51.124265 [ 3830 ] {23d82648-d219-4c29-95ac-dee06eb63f20} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.142502 [ 3830 ] {760e2c25-867e-4ad2-aecd-b08ad570a175} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetStringOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetStringOrDefault();) 2025.03.31 19:05:51.143998 [ 3830 ] {760e2c25-867e-4ad2-aecd-b08ad570a175} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetStringOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.162732 [ 3830 ] {5e371954-fd09-489c-a307-1ab0bf51de69} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt16();) 2025.03.31 19:05:51.164708 [ 3830 ] {5e371954-fd09-489c-a307-1ab0bf51de69} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.181586 [ 3830 ] {bd65b624-6a1d-4984-b4de-717b2df42eef} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt16OrDefault();) 2025.03.31 19:05:51.183204 [ 3830 ] {bd65b624-6a1d-4984-b4de-717b2df42eef} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.199272 [ 3830 ] {fdeaa7b7-aa71-4797-97fa-f68a5bd5b258} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt32();) 2025.03.31 19:05:51.200699 [ 3830 ] {fdeaa7b7-aa71-4797-97fa-f68a5bd5b258} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.218238 [ 3830 ] {3d8e623d-57a4-4b65-ab96-dcd80e4f68de} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt32OrDefault();) 2025.03.31 19:05:51.219881 [ 3830 ] {3d8e623d-57a4-4b65-ab96-dcd80e4f68de} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.236121 [ 3830 ] {8c50263f-826c-43fc-adfa-8bb1363cbaa5} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt64();) 2025.03.31 19:05:51.237701 [ 3830 ] {8c50263f-826c-43fc-adfa-8bb1363cbaa5} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.303839 [ 3830 ] {bda6987a-9d77-448c-ac98-bf9f3fccb79f} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt64OrDefault();) 2025.03.31 19:05:51.305635 [ 3830 ] {bda6987a-9d77-448c-ac98-bf9f3fccb79f} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.323600 [ 3830 ] {a4e7ce59-3eb8-4016-b1a0-7485bc2f3e0b} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt8();) 2025.03.31 19:05:51.325229 [ 3830 ] {a4e7ce59-3eb8-4016-b1a0-7485bc2f3e0b} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.357300 [ 3830 ] {63777fd7-c223-4ff3-9922-cf658346a921} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUInt8OrDefault();) 2025.03.31 19:05:51.358983 [ 3830 ] {63777fd7-c223-4ff3-9922-cf658346a921} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.376043 [ 3830 ] {14793a1e-3457-43a2-af73-d9d380b9b370} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUUID();) 2025.03.31 19:05:51.377553 [ 3830 ] {14793a1e-3457-43a2-af73-d9d380b9b370} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.480628 [ 3830 ] {d271ed18-eb0d-4515-aebe-88f9acfb20ef} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictGetUUIDOrDefault();) 2025.03.31 19:05:51.482396 [ 3830 ] {d271ed18-eb0d-4515-aebe-88f9acfb20ef} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.500782 [ 3830 ] {191586a2-d546-418b-9a01-f2a722a0f4ee} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictHas: In scope SELECT dictHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictHas();) 2025.03.31 19:05:51.502590 [ 3830 ] {191586a2-d546-418b-9a01-f2a722a0f4ee} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictHas: In scope SELECT dictHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.520114 [ 3830 ] {6fbbf5cd-2cdb-49ae-b9b7-70a9b0b1a282} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 0, should be 3: In scope SELECT dictIsIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dictIsIn();) 2025.03.31 19:05:51.521959 [ 3830 ] {6fbbf5cd-2cdb-49ae-b9b7-70a9b0b1a282} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 0, should be 3: In scope SELECT dictIsIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.578238 [ 3830 ] {1d61a17e-8cf7-48c9-8bcf-8865ab24de4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT distanceL1();) 2025.03.31 19:05:51.579914 [ 3830 ] {1d61a17e-8cf7-48c9-8bcf-8865ab24de4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.596479 [ 3830 ] {8de7aca1-e30e-45da-91ad-0b5feb8edcd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT distanceL2();) 2025.03.31 19:05:51.598040 [ 3830 ] {8de7aca1-e30e-45da-91ad-0b5feb8edcd8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Distance doesn't match: passed 0, should be 2: In scope SELECT distanceL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.615281 [ 3830 ] {5cb14ee9-177d-4f15-ab62-ff13d5985a92} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT distanceL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT distanceL2Squared();) 2025.03.31 19:05:51.616857 [ 3830 ] {5cb14ee9-177d-4f15-ab62-ff13d5985a92} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredDistance doesn't match: passed 0, should be 2: In scope SELECT distanceL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.661114 [ 3830 ] {c75d60cb-9344-4968-875d-ff0d3e26756d} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT distanceLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT distanceLinf();) 2025.03.31 19:05:51.662849 [ 3830 ] {c75d60cb-9344-4968-875d-ff0d3e26756d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfDistance doesn't match: passed 0, should be 2: In scope SELECT distanceLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.678622 [ 3830 ] {f162a332-8d18-4155-a5fd-af8cf6396de5} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT distanceLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT distanceLp();) 2025.03.31 19:05:51.680102 [ 3830 ] {f162a332-8d18-4155-a5fd-af8cf6396de5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 0, should be 3: In scope SELECT distanceLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.735905 [ 3830 ] {f328a760-36cd-4d86-8d31-c4067b3c8611} executeQuery: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 0, should be 2: In scope SELECT divide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT divide();) 2025.03.31 19:05:51.737434 [ 3830 ] {f328a760-36cd-4d86-8d31-c4067b3c8611} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divide doesn't match: passed 0, should be 2: In scope SELECT divide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.850075 [ 3830 ] {52e2ffc7-aefc-40f9-8508-82558ed12635} executeQuery: Code: 42. DB::Exception: Number of arguments for function divideDecimal does not match: 2 or 3 expected: In scope SELECT divideDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT divideDecimal();) 2025.03.31 19:05:51.851779 [ 3830 ] {52e2ffc7-aefc-40f9-8508-82558ed12635} TCPHandler: Code: 42. DB::Exception: Number of arguments for function divideDecimal does not match: 2 or 3 expected: In scope SELECT divideDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:51.970281 [ 3830 ] {ebc23790-bcf2-4d38-b953-58343060fe2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 0, should be 1: In scope SELECT domain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT domain();) 2025.03.31 19:05:51.972094 [ 3830 ] {ebc23790-bcf2-4d38-b953-58343060fe2d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 0, should be 1: In scope SELECT domain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:52.049254 [ 3830 ] {631f39b9-c409-459d-8bc9-eaf83b3cafe2} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 0, should be 1: In scope SELECT domainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT domainRFC();) 2025.03.31 19:05:52.051283 [ 3830 ] {631f39b9-c409-459d-8bc9-eaf83b3cafe2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 0, should be 1: In scope SELECT domainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:52.115949 [ 3830 ] {bb7350d5-4b82-4302-8bf9-c8df63246805} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT domainWithoutWWW();) 2025.03.31 19:05:52.117405 [ 3830 ] {bb7350d5-4b82-4302-8bf9-c8df63246805} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWW(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:52.126532 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:52.152438 [ 3830 ] {fb620257-e747-4fa1-88f6-5ee76a0c0e15} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT domainWithoutWWWRFC();) 2025.03.31 19:05:52.154107 [ 3830 ] {fb620257-e747-4fa1-88f6-5ee76a0c0e15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 0, should be 1: In scope SELECT domainWithoutWWWRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:52.172907 [ 3830 ] {ec0cf7bd-30fd-433c-a951-7554f1d7fc2e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT dotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dotProduct();) 2025.03.31 19:05:52.174836 [ 3830 ] {ec0cf7bd-30fd-433c-a951-7554f1d7fc2e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT dotProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:52.190452 [ 3830 ] {58290027-8c69-433f-bbff-5a70fbe2ccf3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 0, should be 1: In scope SELECT dumpColumnStructure(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dumpColumnStructure();) 2025.03.31 19:05:52.191891 [ 3830 ] {58290027-8c69-433f-bbff-5a70fbe2ccf3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 0, should be 1: In scope SELECT dumpColumnStructure(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:52.208852 [ 3830 ] {6ad8a776-1b40-4301-8347-32537a98b9ab} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 0, should be 2: In scope SELECT dynamicElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dynamicElement();) 2025.03.31 19:05:52.210690 [ 3830 ] {6ad8a776-1b40-4301-8347-32537a98b9ab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicElement doesn't match: passed 0, should be 2: In scope SELECT dynamicElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:52.226351 [ 3830 ] {551a62bf-8841-418f-b62d-34f9d9f9f8bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 0, should be 1: In scope SELECT dynamicType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT dynamicType();) 2025.03.31 19:05:52.227875 [ 3830 ] {551a62bf-8841-418f-b62d-34f9d9f9f8bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 0, should be 1: In scope SELECT dynamicType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:52.335468 [ 3830 ] {5ca5a4c1-27c2-4364-b5a7-2cc36008f59c} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT editDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT editDistance();) 2025.03.31 19:05:52.336901 [ 3830 ] {5ca5a4c1-27c2-4364-b5a7-2cc36008f59c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT editDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:52.352293 [ 3830 ] {850155df-662a-43bc-93dd-1390880e8f0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT editDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT editDistanceUTF8();) 2025.03.31 19:05:52.353978 [ 3830 ] {850155df-662a-43bc-93dd-1390880e8f0f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT editDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:52.426122 [ 3830 ] {e736e496-5fde-43eb-92c2-63354e6d6103} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 0, should be 1: In scope SELECT empty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT empty();) 2025.03.31 19:05:52.427481 [ 3830 ] {e736e496-5fde-43eb-92c2-63354e6d6103} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 0, should be 1: In scope SELECT empty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:52.899229 [ 3830 ] {8cdbcb1e-ac1a-42ea-b999-0f654ffb46c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 0, should be 1: In scope SELECT emptyArrayToSingle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT emptyArrayToSingle();) 2025.03.31 19:05:52.900923 [ 3830 ] {8cdbcb1e-ac1a-42ea-b999-0f654ffb46c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 0, should be 1: In scope SELECT emptyArrayToSingle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.142841 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:53.433588 [ 3830 ] {da05a735-6c5b-41ae-823a-37a77377a8e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT encodeURLComponent();) 2025.03.31 19:05:53.435471 [ 3830 ] {da05a735-6c5b-41ae-823a-37a77377a8e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.454131 [ 3830 ] {7bb008f5-eaf0-4889-8915-35726e933fb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT encodeURLFormComponent();) 2025.03.31 19:05:53.456223 [ 3830 ] {7bb008f5-eaf0-4889-8915-35726e933fb7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 0, should be 1: In scope SELECT encodeURLFormComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.525274 [ 3830 ] {5a1d611c-f04e-4409-98be-30dd6e5a8a9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT encodeXMLComponent();) 2025.03.31 19:05:53.527283 [ 3830 ] {5a1d611c-f04e-4409-98be-30dd6e5a8a9f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 0, should be 1: In scope SELECT encodeXMLComponent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.545649 [ 3830 ] {467095fc-9531-42ce-9288-202430dc0b80} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT encrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT encrypt();) 2025.03.31 19:05:53.547476 [ 3830 ] {467095fc-9531-42ce-9288-202430dc0b80} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT encrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.563897 [ 3830 ] {16059ab0-4915-486b-b637-8ebba9ea1721} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 0, should be 2: In scope SELECT endsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT endsWith();) 2025.03.31 19:05:53.565618 [ 3830 ] {16059ab0-4915-486b-b637-8ebba9ea1721} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWith doesn't match: passed 0, should be 2: In scope SELECT endsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.655666 [ 3830 ] {e8f74e66-e450-45ef-9880-62c5fb72ad33} executeQuery: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT endsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT endsWithUTF8();) 2025.03.31 19:05:53.657305 [ 3830 ] {e8f74e66-e450-45ef-9880-62c5fb72ad33} TCPHandler: Code: 42. DB::Exception: Number of arguments for function endsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT endsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.674154 [ 3830 ] {4d925dc1-2d68-4097-90cb-a5b759498b6e} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function entropy. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT entropy();) 2025.03.31 19:05:53.675840 [ 3830 ] {4d925dc1-2d68-4097-90cb-a5b759498b6e} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function entropy. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.691503 [ 3830 ] {e7c227bd-10e2-4df5-89cf-94db1cabed56} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 0, should be 2: In scope SELECT equals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT equals();) 2025.03.31 19:05:53.693003 [ 3830 ] {e7c227bd-10e2-4df5-89cf-94db1cabed56} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 0, should be 2: In scope SELECT equals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.710866 [ 3830 ] {7d629934-8e9f-4bd5-b653-a351032aedd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 0, should be 1: In scope SELECT erf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT erf();) 2025.03.31 19:05:53.712486 [ 3830 ] {7d629934-8e9f-4bd5-b653-a351032aedd2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 0, should be 1: In scope SELECT erf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.732098 [ 3830 ] {1e39282c-29b2-4370-82b1-395b55faee7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 0, should be 1: In scope SELECT erfc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT erfc();) 2025.03.31 19:05:53.734182 [ 3830 ] {1e39282c-29b2-4370-82b1-395b55faee7f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 0, should be 1: In scope SELECT erfc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.751477 [ 3830 ] {edcb9409-e277-4d65-9949-afc6be222bc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 0, should be 1: In scope SELECT errorCodeToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT errorCodeToName();) 2025.03.31 19:05:53.753282 [ 3830 ] {edcb9409-e277-4d65-9949-afc6be222bc5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 0, should be 1: In scope SELECT errorCodeToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.860827 [ 3830 ] {97cd4889-ad55-47eb-b6cd-77a5139a0d3c} executeQuery: Code: 36. DB::Exception: Function evalMLMethod requires at least one argument: In scope SELECT evalMLMethod(). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT evalMLMethod();) 2025.03.31 19:05:53.862493 [ 3830 ] {97cd4889-ad55-47eb-b6cd-77a5139a0d3c} TCPHandler: Code: 36. DB::Exception: Function evalMLMethod requires at least one argument: In scope SELECT evalMLMethod(). (BAD_ARGUMENTS) 2025.03.31 19:05:53.926565 [ 3830 ] {4d45e689-7dc4-4656-a3ef-326593af6819} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 0, should be 1: In scope SELECT exp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exp();) 2025.03.31 19:05:53.928087 [ 3830 ] {4d45e689-7dc4-4656-a3ef-326593af6819} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 0, should be 1: In scope SELECT exp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.945207 [ 3830 ] {b7ea38e9-7ada-4a91-a9e4-d790137a8e4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 0, should be 1: In scope SELECT exp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exp10();) 2025.03.31 19:05:53.947421 [ 3830 ] {b7ea38e9-7ada-4a91-a9e4-d790137a8e4b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 0, should be 1: In scope SELECT exp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.964349 [ 3830 ] {0ccc5712-72f2-4569-8f0f-7283a0178ab8} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 0, should be 1: In scope SELECT exp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exp2();) 2025.03.31 19:05:53.965861 [ 3830 ] {0ccc5712-72f2-4569-8f0f-7283a0178ab8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 0, should be 1: In scope SELECT exp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:53.983500 [ 3830 ] {d9ad102b-eeb9-410f-b7de-fa5fd1933650} executeQuery: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exponentialMovingAverage();) 2025.03.31 19:05:53.985415 [ 3830 ] {d9ad102b-eeb9-410f-b7de-fa5fd1933650} TCPHandler: Code: 42. DB::Exception: Aggregate function exponentialMovingAverage requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.003616 [ 3830 ] {c2ebac6c-bd68-4ed8-a250-df6c768a3b8e} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exponentialTimeDecayedAvg();) 2025.03.31 19:05:54.005215 [ 3830 ] {c2ebac6c-bd68-4ed8-a250-df6c768a3b8e} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.023078 [ 3830 ] {0dee6a7b-e373-48e2-adc8-48a8c4ce0426} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exponentialTimeDecayedCount();) 2025.03.31 19:05:54.024680 [ 3830 ] {0dee6a7b-e373-48e2-adc8-48a8c4ce0426} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.046810 [ 3830 ] {9dff8ea3-fd4f-465c-90a5-cc9c54810787} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exponentialTimeDecayedMax();) 2025.03.31 19:05:54.048501 [ 3830 ] {9dff8ea3-fd4f-465c-90a5-cc9c54810787} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.065647 [ 3830 ] {cd197068-d80e-480c-ae46-19eebac17d6d} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT exponentialTimeDecayedSum();) 2025.03.31 19:05:54.067362 [ 3830 ] {cd197068-d80e-480c-ae46-19eebac17d6d} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.084700 [ 3830 ] {0048ab1c-af77-4cec-9a67-53f6b05bbae5} executeQuery: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 0, should be 2: In scope SELECT extract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extract();) 2025.03.31 19:05:54.086334 [ 3830 ] {0048ab1c-af77-4cec-9a67-53f6b05bbae5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extract doesn't match: passed 0, should be 2: In scope SELECT extract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.105296 [ 3830 ] {f317403d-91fc-47f1-a85b-4645ff90d74f} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 0, should be 2: In scope SELECT extractAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractAll();) 2025.03.31 19:05:54.107118 [ 3830 ] {f317403d-91fc-47f1-a85b-4645ff90d74f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAll doesn't match: passed 0, should be 2: In scope SELECT extractAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.124870 [ 3830 ] {1af18473-2c4b-4d11-90a9-f0aaec84217c} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractAllGroups();) 2025.03.31 19:05:54.126768 [ 3830 ] {1af18473-2c4b-4d11-90a9-f0aaec84217c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.145419 [ 3830 ] {92343dd5-4e6b-4596-8297-0b7c15b656ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractAllGroupsHorizontal();) 2025.03.31 19:05:54.147316 [ 3830 ] {92343dd5-4e6b-4596-8297-0b7c15b656ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsHorizontal doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsHorizontal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.164227 [ 3830 ] {c1302e7d-db24-4761-a827-11824cb1ad88} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsVertical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractAllGroupsVertical();) 2025.03.31 19:05:54.165846 [ 3830 ] {c1302e7d-db24-4761-a827-11824cb1ad88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractAllGroupsVertical doesn't match: passed 0, should be 2: In scope SELECT extractAllGroupsVertical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.182544 [ 3830 ] {b17aa266-bbf9-4bb4-8b96-19ddd93c75f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 0, should be 2: In scope SELECT extractGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractGroups();) 2025.03.31 19:05:54.184331 [ 3830 ] {b17aa266-bbf9-4bb4-8b96-19ddd93c75f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractGroups doesn't match: passed 0, should be 2: In scope SELECT extractGroups(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.202102 [ 3830 ] {57fa45b3-ef36-437d-ad91-7ade69bf7c5b} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractKeyValuePairs();) 2025.03.31 19:05:54.203852 [ 3830 ] {57fa45b3-ef36-437d-ad91-7ade69bf7c5b} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.221698 [ 3830 ] {08cc0a06-e145-49d4-8770-c7a1d99e70a1} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairsWithEscaping(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractKeyValuePairsWithEscaping();) 2025.03.31 19:05:54.223502 [ 3830 ] {08cc0a06-e145-49d4-8770-c7a1d99e70a1} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT extractKeyValuePairsWithEscaping(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.246738 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:54.291160 [ 3830 ] {28ab1715-9de0-458a-b356-7d345eb9514a} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 0, should be 1: In scope SELECT extractTextFromHTML(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractTextFromHTML();) 2025.03.31 19:05:54.292809 [ 3830 ] {28ab1715-9de0-458a-b356-7d345eb9514a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 0, should be 1: In scope SELECT extractTextFromHTML(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.309390 [ 3830 ] {babc2570-a06f-4f23-8cac-7e239c9c1c62} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 0, should be 2: In scope SELECT extractURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractURLParameter();) 2025.03.31 19:05:54.311082 [ 3830 ] {babc2570-a06f-4f23-8cac-7e239c9c1c62} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameter doesn't match: passed 0, should be 2: In scope SELECT extractURLParameter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.327883 [ 3830 ] {9e2e29c1-bdeb-44dd-a409-c699fe69fede} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 0, should be 1: In scope SELECT extractURLParameterNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractURLParameterNames();) 2025.03.31 19:05:54.329502 [ 3830 ] {9e2e29c1-bdeb-44dd-a409-c699fe69fede} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 0, should be 1: In scope SELECT extractURLParameterNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.347662 [ 3830 ] {2dd88f27-4e37-4b4b-b290-49770a5c412f} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 0, should be 1: In scope SELECT extractURLParameters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT extractURLParameters();) 2025.03.31 19:05:54.349246 [ 3830 ] {2dd88f27-4e37-4b4b-b290-49770a5c412f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 0, should be 1: In scope SELECT extractURLParameters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.367926 [ 3830 ] {28698f45-8280-4af7-83b3-5d005440e2cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 0, should be 1: In scope SELECT factorial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT factorial();) 2025.03.31 19:05:54.369644 [ 3830 ] {28698f45-8280-4af7-83b3-5d005440e2cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 0, should be 1: In scope SELECT factorial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.491296 [ 3830 ] {6f1da73f-aea8-4680-8cf6-aacc021f47a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 0, should be 1 or 2: In scope SELECT file(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT file();) 2025.03.31 19:05:54.493082 [ 3830 ] {6f1da73f-aea8-4680-8cf6-aacc021f47a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function file doesn't match: passed 0, should be 1 or 2: In scope SELECT file(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.603644 [ 3830 ] {2f37d45f-98da-4772-9e22-414369169000} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 0, should be 1: In scope SELECT finalizeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT finalizeAggregation();) 2025.03.31 19:05:54.605261 [ 3830 ] {2f37d45f-98da-4772-9e22-414369169000} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 0, should be 1: In scope SELECT finalizeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.683971 [ 3830 ] {63aa7540-def5-486d-9b5a-1de362d68980} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 0, should be 1: In scope SELECT firstLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT firstLine();) 2025.03.31 19:05:54.685925 [ 3830 ] {63aa7540-def5-486d-9b5a-1de362d68980} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 0, should be 1: In scope SELECT firstLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.702365 [ 3830 ] {2a64bb10-109f-4cfc-b4fd-1c0617afec0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT firstSignificantSubdomain();) 2025.03.31 19:05:54.703863 [ 3830 ] {2a64bb10-109f-4cfc-b4fd-1c0617afec0e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.718772 [ 3830 ] {de63ad1d-3595-47ff-aac4-b5bf71619e05} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT firstSignificantSubdomainCustom();) 2025.03.31 19:05:54.720261 [ 3830 ] {de63ad1d-3595-47ff-aac4-b5bf71619e05} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustom doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.737007 [ 3830 ] {62114a67-e495-451d-9a3c-d0d1a40b7f25} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT firstSignificantSubdomainCustomRFC();) 2025.03.31 19:05:54.738609 [ 3830 ] {62114a67-e495-451d-9a3c-d0d1a40b7f25} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainCustomRFC doesn't match: passed 0, should be 2: In scope SELECT firstSignificantSubdomainCustomRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.755076 [ 3830 ] {7381080a-8375-425d-9cd0-20c598306b3b} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT firstSignificantSubdomainRFC();) 2025.03.31 19:05:54.756685 [ 3830 ] {7381080a-8375-425d-9cd0-20c598306b3b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 0, should be 1: In scope SELECT firstSignificantSubdomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.772193 [ 3830 ] {5be089e5-a95c-4eb5-8f60-1fbc74271918} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT first_value();) 2025.03.31 19:05:54.773683 [ 3830 ] {5be089e5-a95c-4eb5-8f60-1fbc74271918} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.790791 [ 3830 ] {eefdb3c3-f131-4bb7-b482-23447dc8575c} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT first_value_respect_nulls();) 2025.03.31 19:05:54.792344 [ 3830 ] {eefdb3c3-f131-4bb7-b482-23447dc8575c} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.856530 [ 3830 ] {73631766-5abb-4ace-8145-40273db7b838} executeQuery: Code: 42. DB::Exception: Aggregate function flameGraph requires 1 to 3 arguments : trace, [size = 1], [ptr = 0]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT flameGraph();) 2025.03.31 19:05:54.858209 [ 3830 ] {73631766-5abb-4ace-8145-40273db7b838} TCPHandler: Code: 42. DB::Exception: Aggregate function flameGraph requires 1 to 3 arguments : trace, [size = 1], [ptr = 0]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:54.875805 [ 3830 ] {097e3112-1228-44e2-991b-2b4bc7f6fb22} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT flatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT flatten();) 2025.03.31 19:05:54.877368 [ 3830 ] {097e3112-1228-44e2-991b-2b4bc7f6fb22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 0, should be 1: In scope SELECT flatten(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.056558 [ 3830 ] {24ec49a3-bf5d-4e19-a600-34229560220e} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 0, should be 1: In scope SELECT flattenTuple(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT flattenTuple();) 2025.03.31 19:05:55.057981 [ 3830 ] {24ec49a3-bf5d-4e19-a600-34229560220e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 0, should be 1: In scope SELECT flattenTuple(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.139845 [ 3830 ] {67c62316-ec05-4833-8428-35dbfe7c0391} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT floor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT floor();) 2025.03.31 19:05:55.141531 [ 3830 ] {67c62316-ec05-4833-8428-35dbfe7c0391} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'floor'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT floor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.264268 [ 3830 ] {0348823c-2154-4df9-817f-69977972f5bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function format doesn't match: passed 0, should be at least 2: In scope SELECT format(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT format();) 2025.03.31 19:05:55.265989 [ 3830 ] {0348823c-2154-4df9-817f-69977972f5bf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function format doesn't match: passed 0, should be at least 2: In scope SELECT format(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.277046 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:55.282501 [ 3830 ] {244df751-e522-4c21-8e12-ae8b07f9b6bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatDateTime();) 2025.03.31 19:05:55.284017 [ 3830 ] {244df751-e522-4c21-8e12-ae8b07f9b6bc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTime doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.320428 [ 3830 ] {b4bfaa6c-9289-4fe3-9ab9-ef717d905c7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatDateTimeInJodaSyntax doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatDateTimeInJodaSyntax();) 2025.03.31 19:05:55.322289 [ 3830 ] {b4bfaa6c-9289-4fe3-9ab9-ef717d905c7a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatDateTimeInJodaSyntax doesn't match: passed 0, should be 2 or 3: In scope SELECT formatDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.340312 [ 3830 ] {4497bf28-9118-4674-90dc-cd2e7dfb5e71} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 0, should be 1: In scope SELECT formatQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatQuery();) 2025.03.31 19:05:55.342202 [ 3830 ] {4497bf28-9118-4674-90dc-cd2e7dfb5e71} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 0, should be 1: In scope SELECT formatQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.359165 [ 3830 ] {1f70ac39-c00a-4ae2-b342-a08248878836} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQueryOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatQueryOrNull();) 2025.03.31 19:05:55.360896 [ 3830 ] {1f70ac39-c00a-4ae2-b342-a08248878836} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQueryOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.377654 [ 3830 ] {08277200-92e6-4656-a55c-d52be0a41559} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatQuerySingleLine();) 2025.03.31 19:05:55.379399 [ 3830 ] {08277200-92e6-4656-a55c-d52be0a41559} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLine(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.398060 [ 3830 ] {51190ab4-4e29-4523-ad94-f98d07182e00} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLineOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatQuerySingleLineOrNull();) 2025.03.31 19:05:55.399798 [ 3830 ] {51190ab4-4e29-4523-ad94-f98d07182e00} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 0, should be 1: In scope SELECT formatQuerySingleLineOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.415980 [ 3830 ] {a7b71530-49b4-418b-8094-1329b1122af2} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableDecimalSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatReadableDecimalSize();) 2025.03.31 19:05:55.417370 [ 3830 ] {a7b71530-49b4-418b-8094-1329b1122af2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableDecimalSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.476835 [ 3830 ] {5bd001c0-bb36-45c5-97ea-27fe0e174cd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 0, should be 1: In scope SELECT formatReadableQuantity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatReadableQuantity();) 2025.03.31 19:05:55.478397 [ 3830 ] {5bd001c0-bb36-45c5-97ea-27fe0e174cd3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 0, should be 1: In scope SELECT formatReadableQuantity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.496116 [ 3830 ] {157476db-ffe1-4469-af6a-270bd2d9c3be} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatReadableSize();) 2025.03.31 19:05:55.497894 [ 3830 ] {157476db-ffe1-4469-af6a-270bd2d9c3be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 0, should be 1: In scope SELECT formatReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.513196 [ 3830 ] {9890c150-67d1-4377-a85b-6b5a56955f25} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableTimeDelta doesn't match: passed 0, should be at least 1.: In scope SELECT formatReadableTimeDelta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatReadableTimeDelta();) 2025.03.31 19:05:55.514753 [ 3830 ] {9890c150-67d1-4377-a85b-6b5a56955f25} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableTimeDelta doesn't match: passed 0, should be at least 1.: In scope SELECT formatReadableTimeDelta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.532015 [ 3830 ] {75aa2913-e684-4c3a-938d-80d8ee64f05a} executeQuery: Code: 42. DB::Exception: Function formatRow requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatRow();) 2025.03.31 19:05:55.533380 [ 3830 ] {75aa2913-e684-4c3a-938d-80d8ee64f05a} TCPHandler: Code: 42. DB::Exception: Function formatRow requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.551482 [ 3830 ] {f6544a45-43c3-4611-bc61-5aeccf782ffd} executeQuery: Code: 42. DB::Exception: Function formatRowNoNewline requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRowNoNewline(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT formatRowNoNewline();) 2025.03.31 19:05:55.553062 [ 3830 ] {f6544a45-43c3-4611-bc61-5aeccf782ffd} TCPHandler: Code: 42. DB::Exception: Function formatRowNoNewline requires at least two arguments: the format name and its output expression(s): In scope SELECT formatRowNoNewline(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.663230 [ 3830 ] {3ea781fb-7921-4221-8f8a-fd99203ec75f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 0, should be 1: In scope SELECT fragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fragment();) 2025.03.31 19:05:55.664797 [ 3830 ] {3ea781fb-7921-4221-8f8a-fd99203ec75f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 0, should be 1: In scope SELECT fragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.682484 [ 3830 ] {4a9b2124-c7b6-4009-9606-af404ef7f012} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromDaysSinceYearZero();) 2025.03.31 19:05:55.684299 [ 3830 ] {4a9b2124-c7b6-4009-9606-af404ef7f012} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.753659 [ 3830 ] {81eb4c8c-7580-4f60-9114-e04be23b739f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromDaysSinceYearZero32();) 2025.03.31 19:05:55.755538 [ 3830 ] {81eb4c8c-7580-4f60-9114-e04be23b739f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 0, should be 1: In scope SELECT fromDaysSinceYearZero32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.771796 [ 3830 ] {90ab6eb4-2873-4094-9cda-da59a356834b} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromModifiedJulianDay();) 2025.03.31 19:05:55.773541 [ 3830 ] {90ab6eb4-2873-4094-9cda-da59a356834b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.829566 [ 3830 ] {e5533a6d-1aa6-414f-bbd4-bc0e875b1f87} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromModifiedJulianDayOrNull();) 2025.03.31 19:05:55.831161 [ 3830 ] {e5533a6d-1aa6-414f-bbd4-bc0e875b1f87} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT fromModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.847710 [ 3830 ] {5d64fb8a-a124-4dfe-b554-71c85adf9483} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT fromUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUTCTimestamp();) 2025.03.31 19:05:55.849287 [ 3830 ] {5d64fb8a-a124-4dfe-b554-71c85adf9483} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT fromUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.865271 [ 3830 ] {906f1331-2ffd-4811-a031-55cae984e155} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUnixTimestamp();) 2025.03.31 19:05:55.867060 [ 3830 ] {906f1331-2ffd-4811-a031-55cae984e155} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestamp doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.882251 [ 3830 ] {43d97205-3df2-49ce-995f-640deeded82d} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUnixTimestamp64Micro();) 2025.03.31 19:05:55.883759 [ 3830 ] {43d97205-3df2-49ce-995f-640deeded82d} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Micro takes one or two arguments: In scope SELECT fromUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.897256 [ 3830 ] {3110758f-0cd2-4c6c-9c00-3db079439bd2} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUnixTimestamp64Milli();) 2025.03.31 19:05:55.898746 [ 3830 ] {3110758f-0cd2-4c6c-9c00-3db079439bd2} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Milli takes one or two arguments: In scope SELECT fromUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.915240 [ 3830 ] {e037bec1-7485-4422-8915-6adbd1194b4f} executeQuery: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUnixTimestamp64Nano();) 2025.03.31 19:05:55.916849 [ 3830 ] {e037bec1-7485-4422-8915-6adbd1194b4f} TCPHandler: Code: 42. DB::Exception: Function fromUnixTimestamp64Nano takes one or two arguments: In scope SELECT fromUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.919426 [ 4187 ] {0e278ee4-66a3-47ea-8ede-b88de2316774} 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.10457.altinitytest (altinity build)) (from [::1]:57770) (comment: 02473_optimize_old_parts.sh) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_with_merge_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:05:55.922272 [ 4187 ] {0e278ee4-66a3-47ea-8ede-b88de2316774} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:05:55.932310 [ 3830 ] {ad900718-70be-47c4-829d-0c041aca677c} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestampInJodaSyntax doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestampInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fromUnixTimestampInJodaSyntax();) 2025.03.31 19:05:55.934204 [ 3830 ] {ad900718-70be-47c4-829d-0c041aca677c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUnixTimestampInJodaSyntax doesn't match: passed 0, should be 1, 2 or 3: In scope SELECT fromUnixTimestampInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.951504 [ 3830 ] {d77e6a57-7865-42e9-ad27-10942ae081ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT from_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT from_utc_timestamp();) 2025.03.31 19:05:55.953372 [ 3830 ] {d77e6a57-7865-42e9-ad27-10942ae081ed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT from_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:55.997396 [ 3830 ] {6a743942-2228-4249-bedf-eeb7af93f88f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 0, should be 2: In scope SELECT fuzzBits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT fuzzBits();) 2025.03.31 19:05:55.998980 [ 3830 ] {6a743942-2228-4249-bedf-eeb7af93f88f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fuzzBits doesn't match: passed 0, should be 2: In scope SELECT fuzzBits(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.122870 [ 3830 ] {d064a62a-0368-4f6b-9204-6f609044e946} executeQuery: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 0, should be 2: In scope SELECT gcd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT gcd();) 2025.03.31 19:05:56.125014 [ 3830 ] {d064a62a-0368-4f6b-9204-6f609044e946} TCPHandler: Code: 42. DB::Exception: Number of arguments for function gcd doesn't match: passed 0, should be 2: In scope SELECT gcd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.319817 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:56.471015 [ 3830 ] {3f531514-e1e4-41d1-aefa-d3c386ca9100} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 0, should be 4: In scope SELECT geoDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geoDistance();) 2025.03.31 19:05:56.473047 [ 3830 ] {3f531514-e1e4-41d1-aefa-d3c386ca9100} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 0, should be 4: In scope SELECT geoDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.489503 [ 3830 ] {9d036a49-5d62-49bf-a2a2-d3715535448b} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 0, should be 3: In scope SELECT geoToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geoToH3();) 2025.03.31 19:05:56.491526 [ 3830 ] {9d036a49-5d62-49bf-a2a2-d3715535448b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 0, should be 3: In scope SELECT geoToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.525442 [ 3830 ] {8035345a-d00b-4022-8e2a-563444dbe654} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 0, should be 2: In scope SELECT geoToS2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geoToS2();) 2025.03.31 19:05:56.527375 [ 3830 ] {8035345a-d00b-4022-8e2a-563444dbe654} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToS2 doesn't match: passed 0, should be 2: In scope SELECT geoToS2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.543533 [ 3830 ] {b807d800-846a-48a3-b3e1-a46e72061dd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 0, should be 1: In scope SELECT geohashDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geohashDecode();) 2025.03.31 19:05:56.545323 [ 3830 ] {b807d800-846a-48a3-b3e1-a46e72061dd7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 0, should be 1: In scope SELECT geohashDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.564054 [ 3830 ] {28227048-a736-4a50-8e3a-ffc2aec92e9f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'geohashEncode'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT geohashEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geohashEncode();) 2025.03.31 19:05:56.566094 [ 3830 ] {28227048-a736-4a50-8e3a-ffc2aec92e9f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'geohashEncode'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT geohashEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.582142 [ 3830 ] {ef0d376f-9fdc-4607-a52a-07732f7506ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 0, should be 5: In scope SELECT geohashesInBox(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT geohashesInBox();) 2025.03.31 19:05:56.584464 [ 3830 ] {ef0d376f-9fdc-4607-a52a-07732f7506ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 0, should be 5: In scope SELECT geohashesInBox(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.599982 [ 3830 ] {51ed4fba-4591-4ac0-9718-df9bd72d51e4} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getClientHTTPHeader();) 2025.03.31 19:05:56.601329 [ 3830 ] {51ed4fba-4591-4ac0-9718-df9bd72d51e4} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.03.31 19:05:56.617152 [ 3830 ] {4c34eb3a-965e-44d6-bc50-12871e6b6b64} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 0, should be 1: In scope SELECT getMacro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getMacro();) 2025.03.31 19:05:56.618614 [ 3830 ] {4c34eb3a-965e-44d6-bc50-12871e6b6b64} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 0, should be 1: In scope SELECT getMacro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.662093 [ 3830 ] {264ebdce-0f6c-450d-9ce9-e917470a9fb3} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 0, should be 1: In scope SELECT getServerPort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getServerPort();) 2025.03.31 19:05:56.663527 [ 3830 ] {264ebdce-0f6c-450d-9ce9-e917470a9fb3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 0, should be 1: In scope SELECT getServerPort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.680082 [ 3830 ] {a2711e6d-fd64-4cc3-b42a-c7299b069264} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 0, should be 1: In scope SELECT getSetting(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getSetting();) 2025.03.31 19:05:56.681636 [ 3830 ] {a2711e6d-fd64-4cc3-b42a-c7299b069264} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 0, should be 1: In scope SELECT getSetting(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.890726 [ 3830 ] {3603d47d-c137-481b-b05a-3f061eb357b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 0, should be 1: In scope SELECT getSizeOfEnumType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getSizeOfEnumType();) 2025.03.31 19:05:56.892603 [ 3830 ] {3603d47d-c137-481b-b05a-3f061eb357b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 0, should be 1: In scope SELECT getSizeOfEnumType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.909626 [ 3830 ] {f58f1373-d924-42ac-af06-0fb4dcd5cad0} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 0, should be 2: In scope SELECT getSubcolumn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getSubcolumn();) 2025.03.31 19:05:56.911649 [ 3830 ] {f58f1373-d924-42ac-af06-0fb4dcd5cad0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSubcolumn doesn't match: passed 0, should be 2: In scope SELECT getSubcolumn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.929162 [ 3830 ] {36747a0a-1b18-4a7f-8088-8ad3d3b383c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 0, should be 1: In scope SELECT getTypeSerializationStreams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT getTypeSerializationStreams();) 2025.03.31 19:05:56.930924 [ 3830 ] {36747a0a-1b18-4a7f-8088-8ad3d3b383c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 0, should be 1: In scope SELECT getTypeSerializationStreams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.948032 [ 3830 ] {59957720-3e05-4896-a7ba-fd0bd49183f6} executeQuery: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalIn();) 2025.03.31 19:05:56.950131 [ 3830 ] {59957720-3e05-4896-a7ba-fd0bd49183f6} TCPHandler: Code: 42. DB::Exception: Function 'globalIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.964937 [ 3830 ] {c80b6ce6-d2f2-4f4d-9043-8a94ef1ebc62} executeQuery: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalInIgnoreSet();) 2025.03.31 19:05:56.966586 [ 3830 ] {c80b6ce6-d2f2-4f4d-9043-8a94ef1ebc62} TCPHandler: Code: 42. DB::Exception: Function 'globalInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:56.985104 [ 3830 ] {2c585b50-3075-4b59-9fd5-29ade9a2995b} executeQuery: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNotIn();) 2025.03.31 19:05:56.987034 [ 3830 ] {2c585b50-3075-4b59-9fd5-29ade9a2995b} TCPHandler: Code: 42. DB::Exception: Function 'globalNotIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.067973 [ 3830 ] {4c9dc948-19c4-428e-bde9-16d2c4a4a51e} executeQuery: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNotInIgnoreSet();) 2025.03.31 19:05:57.069591 [ 3830 ] {4c9dc948-19c4-428e-bde9-16d2c4a4a51e} TCPHandler: Code: 42. DB::Exception: Function 'globalNotInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.086048 [ 3830 ] {f392911e-7c02-48ca-815a-27b6f42139f0} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNotNullIn();) 2025.03.31 19:05:57.087438 [ 3830 ] {f392911e-7c02-48ca-815a-27b6f42139f0} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.103761 [ 3830 ] {274e8857-9f79-4204-af78-db324e672bd3} executeQuery: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNotNullInIgnoreSet();) 2025.03.31 19:05:57.105292 [ 3830 ] {274e8857-9f79-4204-af78-db324e672bd3} TCPHandler: Code: 42. DB::Exception: Function 'globalNotNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.120676 [ 3830 ] {fc448a27-c1cd-4449-b02e-526d1ab30fa0} executeQuery: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNullIn();) 2025.03.31 19:05:57.122311 [ 3830 ] {fc448a27-c1cd-4449-b02e-526d1ab30fa0} TCPHandler: Code: 42. DB::Exception: Function 'globalNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.137837 [ 3830 ] {43b74c9c-d587-4483-8c1a-415f1fbc674c} executeQuery: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalNullInIgnoreSet();) 2025.03.31 19:05:57.139264 [ 3830 ] {43b74c9c-d587-4483-8c1a-415f1fbc674c} TCPHandler: Code: 42. DB::Exception: Function 'globalNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.154696 [ 3830 ] {cd00e4fd-d388-46dd-87df-e04c57038f06} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 0, should be 1: In scope SELECT globalVariable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT globalVariable();) 2025.03.31 19:05:57.156106 [ 3830 ] {cd00e4fd-d388-46dd-87df-e04c57038f06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 0, should be 1: In scope SELECT globalVariable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.171676 [ 3830 ] {0f5b808b-0510-4acf-a996-077d7a824d21} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 0, should be 4: In scope SELECT greatCircleAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT greatCircleAngle();) 2025.03.31 19:05:57.173185 [ 3830 ] {0f5b808b-0510-4acf-a996-077d7a824d21} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 0, should be 4: In scope SELECT greatCircleAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.189547 [ 3830 ] {7bddf248-999d-4d00-a4f5-40c745ac1d53} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 0, should be 4: In scope SELECT greatCircleDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT greatCircleDistance();) 2025.03.31 19:05:57.191430 [ 3830 ] {7bddf248-999d-4d00-a4f5-40c745ac1d53} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 0, should be 4: In scope SELECT greatCircleDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.207106 [ 3830 ] {3aecbb16-8609-46ef-9c62-655d58bd5ad2} executeQuery: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 0, should be 2: In scope SELECT greater(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT greater();) 2025.03.31 19:05:57.208678 [ 3830 ] {3aecbb16-8609-46ef-9c62-655d58bd5ad2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greater doesn't match: passed 0, should be 2: In scope SELECT greater(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.224649 [ 3830 ] {b3c5de97-232d-4b55-a4a3-10b5fe85c3ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 0, should be 2: In scope SELECT greaterOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT greaterOrEquals();) 2025.03.31 19:05:57.226405 [ 3830 ] {b3c5de97-232d-4b55-a4a3-10b5fe85c3ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greaterOrEquals doesn't match: passed 0, should be 2: In scope SELECT greaterOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.243350 [ 3830 ] {5fe0ea92-a212-4416-bafc-1b8367812706} executeQuery: Code: 42. DB::Exception: Function greatest cannot be called without arguments: In scope SELECT greatest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT greatest();) 2025.03.31 19:05:57.244992 [ 3830 ] {5fe0ea92-a212-4416-bafc-1b8367812706} TCPHandler: Code: 42. DB::Exception: Function greatest cannot be called without arguments: In scope SELECT greatest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.260308 [ 3830 ] {6c0f7f37-6a81-4862-a064-1da263b75bb6} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArray();) 2025.03.31 19:05:57.261692 [ 3830 ] {6c0f7f37-6a81-4862-a064-1da263b75bb6} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.280506 [ 3830 ] {10b82949-d677-4767-b5b7-728ea03f1001} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArrayInsertAt();) 2025.03.31 19:05:57.282449 [ 3830 ] {10b82949-d677-4767-b5b7-728ea03f1001} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayInsertAt requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.297583 [ 3830 ] {d5983ea6-802a-4f43-8844-ec676c908ada} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArrayIntersect();) 2025.03.31 19:05:57.299080 [ 3830 ] {d5983ea6-802a-4f43-8844-ec676c908ada} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.313298 [ 3830 ] {89e322ef-c2be-4a5f-8ec9-1716862bad2a} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArrayLast();) 2025.03.31 19:05:57.314718 [ 3830 ] {89e322ef-c2be-4a5f-8ec9-1716862bad2a} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.328679 [ 3830 ] {f9640fab-7dd9-44d6-9fe2-707e3a516dc9} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArrayMovingAvg();) 2025.03.31 19:05:57.330149 [ 3830 ] {f9640fab-7dd9-44d6-9fe2-707e3a516dc9} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.396428 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:57.399417 [ 3830 ] {5543e7ad-f7ec-4062-8018-b9c56f5343fc} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArrayMovingSum();) 2025.03.31 19:05:57.401129 [ 3830 ] {5543e7ad-f7ec-4062-8018-b9c56f5343fc} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.417416 [ 3830 ] {ac23431f-1ee9-434c-aa2d-9d5d0bda3236} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArraySample();) 2025.03.31 19:05:57.423724 [ 3830 ] {ac23431f-1ee9-434c-aa2d-9d5d0bda3236} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.440189 [ 3830 ] {2ed627a1-bd6a-4285-8ddb-678c6308ec2b} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupArraySorted();) 2025.03.31 19:05:57.442284 [ 3830 ] {2ed627a1-bd6a-4285-8ddb-678c6308ec2b} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.458958 [ 3830 ] {80c7c939-96e0-4574-a863-69b5ed939774} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitAnd();) 2025.03.31 19:05:57.460548 [ 3830 ] {80c7c939-96e0-4574-a863-69b5ed939774} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.477177 [ 3830 ] {37fcfd97-6fcb-4ec2-aaf2-abf989558cf4} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitOr();) 2025.03.31 19:05:57.478832 [ 3830 ] {37fcfd97-6fcb-4ec2-aaf2-abf989558cf4} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.512211 [ 3830 ] {03541692-58a9-41a4-a780-6289fa312f00} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitXor();) 2025.03.31 19:05:57.513876 [ 3830 ] {03541692-58a9-41a4-a780-6289fa312f00} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.528781 [ 3830 ] {f4c2efd4-b8e8-4609-b44c-f23deb06219e} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitmap();) 2025.03.31 19:05:57.530318 [ 3830 ] {f4c2efd4-b8e8-4609-b44c-f23deb06219e} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.545933 [ 3830 ] {fa087449-e3fd-4b0e-8f19-8adb7def250f} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitmapAnd();) 2025.03.31 19:05:57.548027 [ 3830 ] {fa087449-e3fd-4b0e-8f19-8adb7def250f} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.564119 [ 3830 ] {540e5a8d-5728-4102-9f9d-8749e590e13f} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitmapOr();) 2025.03.31 19:05:57.565920 [ 3830 ] {540e5a8d-5728-4102-9f9d-8749e590e13f} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.580570 [ 3830 ] {70349fe8-a8ed-464b-9e84-a4ed3ba3db31} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupBitmapXor();) 2025.03.31 19:05:57.582090 [ 3830 ] {70349fe8-a8ed-464b-9e84-a4ed3ba3db31} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.597651 [ 3830 ] {18d93ecb-da55-41de-aad4-2c7390d6f18c} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupConcat();) 2025.03.31 19:05:57.599264 [ 3830 ] {18d93ecb-da55-41de-aad4-2c7390d6f18c} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.616086 [ 3830 ] {9ad0ffed-f528-492e-b84b-27e6c2ab164c} executeQuery: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT groupUniqArray();) 2025.03.31 19:05:57.617608 [ 3830 ] {9ad0ffed-f528-492e-b84b-27e6c2ab164c} TCPHandler: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.633476 [ 3830 ] {d260d548-4e22-42de-8723-1e17947f4d19} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT group_concat();) 2025.03.31 19:05:57.705288 [ 3830 ] {d260d548-4e22-42de-8723-1e17947f4d19} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.720854 [ 3830 ] {d7db4d49-c767-47db-a968-16a87240cdd0} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3CellAreaM2();) 2025.03.31 19:05:57.722435 [ 3830 ] {d7db4d49-c767-47db-a968-16a87240cdd0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.737960 [ 3830 ] {5be7c21b-6c0b-4a9e-a7b2-2092c9a278cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaRads2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3CellAreaRads2();) 2025.03.31 19:05:57.739476 [ 3830 ] {5be7c21b-6c0b-4a9e-a7b2-2092c9a278cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 0, should be 1: In scope SELECT h3CellAreaRads2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.757148 [ 3830 ] {b4c1a5a6-3c1a-410a-9b80-182f04775ab1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 0, should be 2: In scope SELECT h3Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3Distance();) 2025.03.31 19:05:57.758824 [ 3830 ] {b4c1a5a6-3c1a-410a-9b80-182f04775ab1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Distance doesn't match: passed 0, should be 2: In scope SELECT h3Distance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.806481 [ 3830 ] {87db2140-5b5f-40d8-8611-1761dbbc1c82} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 0, should be 1: In scope SELECT h3EdgeAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3EdgeAngle();) 2025.03.31 19:05:57.807955 [ 3830 ] {87db2140-5b5f-40d8-8611-1761dbbc1c82} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 0, should be 1: In scope SELECT h3EdgeAngle(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.824138 [ 3830 ] {2babe545-091b-47a8-9ae3-c5253280d966} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3EdgeLengthKm();) 2025.03.31 19:05:57.825840 [ 3830 ] {2babe545-091b-47a8-9ae3-c5253280d966} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.842291 [ 3830 ] {43be9ed0-6cbe-42e2-a105-e936502e4368} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3EdgeLengthM();) 2025.03.31 19:05:57.843768 [ 3830 ] {43be9ed0-6cbe-42e2-a105-e936502e4368} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3EdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.859969 [ 3830 ] {34d33db3-fffe-446e-84bf-3b534aaf3052} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ExactEdgeLengthKm();) 2025.03.31 19:05:57.861639 [ 3830 ] {34d33db3-fffe-446e-84bf-3b534aaf3052} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.878473 [ 3830 ] {4c246ba5-14be-4790-93ef-4e09d545e827} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ExactEdgeLengthM();) 2025.03.31 19:05:57.880345 [ 3830 ] {4c246ba5-14be-4790-93ef-4e09d545e827} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.894937 [ 3830 ] {0572ebef-b5d1-4a19-afc3-9c99c5f46fbd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ExactEdgeLengthRads();) 2025.03.31 19:05:57.899020 [ 3830 ] {0572ebef-b5d1-4a19-afc3-9c99c5f46fbd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 0, should be 1: In scope SELECT h3ExactEdgeLengthRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:57.914731 [ 3830 ] {32d121ef-5bd9-44fe-9c2c-9587fc97a4e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 0, should be 1: In scope SELECT h3GetBaseCell(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetBaseCell();) 2025.03.31 19:05:57.916131 [ 3830 ] {32d121ef-5bd9-44fe-9c2c-9587fc97a4e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 0, should be 1: In scope SELECT h3GetBaseCell(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.021111 [ 3830 ] {9e44b0a8-3109-472e-b4ed-63a87dac3602} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge();) 2025.03.31 19:05:58.022864 [ 3830 ] {9e44b0a8-3109-472e-b4ed-63a87dac3602} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.041144 [ 3830 ] {1c772e8e-3a77-4072-9746-1f1157273123} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 0, should be 1: In scope SELECT h3GetFaces(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetFaces();) 2025.03.31 19:05:58.042935 [ 3830 ] {1c772e8e-3a77-4072-9746-1f1157273123} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 0, should be 1: In scope SELECT h3GetFaces(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.058371 [ 3830 ] {8b9ca36a-7bb9-49ad-b6d2-4dc8ca1c44c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetIndexesFromUnidirectionalEdge();) 2025.03.31 19:05:58.060010 [ 3830 ] {8b9ca36a-7bb9-49ad-b6d2-4dc8ca1c44c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.075100 [ 3830 ] {3bbaf448-c8f0-4878-9cc3-6f7a03de30ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge();) 2025.03.31 19:05:58.076508 [ 3830 ] {3bbaf448-c8f0-4878-9cc3-6f7a03de30ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 0, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.093208 [ 3830 ] {9d1ebe15-a39f-4fa7-aa20-06ca94b008cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 0, should be 1: In scope SELECT h3GetPentagonIndexes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetPentagonIndexes();) 2025.03.31 19:05:58.094823 [ 3830 ] {9d1ebe15-a39f-4fa7-aa20-06ca94b008cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 0, should be 1: In scope SELECT h3GetPentagonIndexes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.284110 [ 3830 ] {6abf1cf5-f79e-4d59-b888-10a9f24de4fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 0, should be 1: In scope SELECT h3GetResolution(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetResolution();) 2025.03.31 19:05:58.285870 [ 3830 ] {6abf1cf5-f79e-4d59-b888-10a9f24de4fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 0, should be 1: In scope SELECT h3GetResolution(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.302096 [ 3830 ] {5b8851de-63f2-40d7-a02f-cf4ad9b6b6a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 0, should be 2: In scope SELECT h3GetUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetUnidirectionalEdge();) 2025.03.31 19:05:58.303716 [ 3830 ] {5b8851de-63f2-40d7-a02f-cf4ad9b6b6a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdge doesn't match: passed 0, should be 2: In scope SELECT h3GetUnidirectionalEdge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.320465 [ 3830 ] {e27a0864-55b6-438a-84a5-0a565b4da853} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetUnidirectionalEdgeBoundary();) 2025.03.31 19:05:58.322452 [ 3830 ] {e27a0864-55b6-438a-84a5-0a565b4da853} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.338891 [ 3830 ] {c883d510-545f-48d1-968c-217df5897e3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon();) 2025.03.31 19:05:58.340401 [ 3830 ] {c883d510-545f-48d1-968c-217df5897e3e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 0, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.355461 [ 3830 ] {04f2626a-2314-4739-b809-b7073334af5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaKm2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3HexAreaKm2();) 2025.03.31 19:05:58.357065 [ 3830 ] {04f2626a-2314-4739-b809-b7073334af5c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaKm2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.438163 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:58.470889 [ 3830 ] {866fd490-58c5-419e-bc9f-872056f1cfae} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3HexAreaM2();) 2025.03.31 19:05:58.472430 [ 3830 ] {866fd490-58c5-419e-bc9f-872056f1cfae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 0, should be 1: In scope SELECT h3HexAreaM2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.524741 [ 3830 ] {c8f1244c-d2df-4340-ace5-4d922bfab0d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 0, should be 2: In scope SELECT h3HexRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3HexRing();) 2025.03.31 19:05:58.526374 [ 3830 ] {c8f1244c-d2df-4340-ace5-4d922bfab0d7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexRing doesn't match: passed 0, should be 2: In scope SELECT h3HexRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.542450 [ 3830 ] {80f4a154-3c1c-4439-823b-87594d149f02} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 0, should be 2: In scope SELECT h3IndexesAreNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3IndexesAreNeighbors();) 2025.03.31 19:05:58.543950 [ 3830 ] {80f4a154-3c1c-4439-823b-87594d149f02} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IndexesAreNeighbors doesn't match: passed 0, should be 2: In scope SELECT h3IndexesAreNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.559468 [ 3830 ] {7a1bb5cc-e9c5-4cf4-a3d8-cf6bbef05998} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 0, should be 1: In scope SELECT h3IsPentagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3IsPentagon();) 2025.03.31 19:05:58.560906 [ 3830 ] {7a1bb5cc-e9c5-4cf4-a3d8-cf6bbef05998} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 0, should be 1: In scope SELECT h3IsPentagon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.577218 [ 3830 ] {1fd55610-aae6-4c74-b1be-de8f9bf05a0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 0, should be 1: In scope SELECT h3IsResClassIII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3IsResClassIII();) 2025.03.31 19:05:58.648118 [ 3830 ] {1fd55610-aae6-4c74-b1be-de8f9bf05a0e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 0, should be 1: In scope SELECT h3IsResClassIII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.663785 [ 3830 ] {0f1a6c32-bd40-4488-a873-a4c69807bb38} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 0, should be 1: In scope SELECT h3IsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3IsValid();) 2025.03.31 19:05:58.665218 [ 3830 ] {0f1a6c32-bd40-4488-a873-a4c69807bb38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 0, should be 1: In scope SELECT h3IsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.681699 [ 3830 ] {35bf0bb4-d2e8-4ed1-b2ff-3fef79b59343} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 0, should be 2: In scope SELECT h3Line(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3Line();) 2025.03.31 19:05:58.683678 [ 3830 ] {35bf0bb4-d2e8-4ed1-b2ff-3fef79b59343} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3Line doesn't match: passed 0, should be 2: In scope SELECT h3Line(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.718908 [ 3830 ] {635150b1-85cc-416d-96b4-6da704efe1dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 0, should be 1: In scope SELECT h3NumHexagons(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3NumHexagons();) 2025.03.31 19:05:58.720483 [ 3830 ] {635150b1-85cc-416d-96b4-6da704efe1dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 0, should be 1: In scope SELECT h3NumHexagons(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.735992 [ 3830 ] {6b4aaaff-22fb-468e-ab56-81f5f2c048a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 0, should be 4: In scope SELECT h3PointDistKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3PointDistKm();) 2025.03.31 19:05:58.737454 [ 3830 ] {6b4aaaff-22fb-468e-ab56-81f5f2c048a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 0, should be 4: In scope SELECT h3PointDistKm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.753491 [ 3830 ] {155d9166-5da4-4b0e-81d9-d7ab75c62b6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 0, should be 4: In scope SELECT h3PointDistM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3PointDistM();) 2025.03.31 19:05:58.755093 [ 3830 ] {155d9166-5da4-4b0e-81d9-d7ab75c62b6a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 0, should be 4: In scope SELECT h3PointDistM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.771400 [ 3830 ] {bf1a9c6b-c9ce-4072-b150-19ee5e428fbb} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 0, should be 4: In scope SELECT h3PointDistRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3PointDistRads();) 2025.03.31 19:05:58.772908 [ 3830 ] {bf1a9c6b-c9ce-4072-b150-19ee5e428fbb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 0, should be 4: In scope SELECT h3PointDistRads(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.788340 [ 3830 ] {eabae07d-5510-41b7-961f-eeea3718886a} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 0, should be 2: In scope SELECT h3ToCenterChild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToCenterChild();) 2025.03.31 19:05:58.789935 [ 3830 ] {eabae07d-5510-41b7-961f-eeea3718886a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToCenterChild doesn't match: passed 0, should be 2: In scope SELECT h3ToCenterChild(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.805398 [ 3830 ] {04f122bc-343d-4c4b-afe3-6abbbc391431} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 0, should be 2: In scope SELECT h3ToChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToChildren();) 2025.03.31 19:05:58.807174 [ 3830 ] {04f122bc-343d-4c4b-afe3-6abbbc391431} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToChildren doesn't match: passed 0, should be 2: In scope SELECT h3ToChildren(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.822870 [ 3830 ] {3f5d5b38-4582-4948-b24c-bc2774169a50} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 0, should be 1: In scope SELECT h3ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToGeo();) 2025.03.31 19:05:58.824377 [ 3830 ] {3f5d5b38-4582-4948-b24c-bc2774169a50} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 0, should be 1: In scope SELECT h3ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.881490 [ 3830 ] {cd23bbd1-d604-4d41-b079-a26b7e841828} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 0, should be 1: In scope SELECT h3ToGeoBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToGeoBoundary();) 2025.03.31 19:05:58.883035 [ 3830 ] {cd23bbd1-d604-4d41-b079-a26b7e841828} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 0, should be 1: In scope SELECT h3ToGeoBoundary(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.914033 [ 3830 ] {a3555cd6-dee2-4845-accd-4b57e9c0563f} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 0, should be 2: In scope SELECT h3ToParent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToParent();) 2025.03.31 19:05:58.915459 [ 3830 ] {a3555cd6-dee2-4845-accd-4b57e9c0563f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToParent doesn't match: passed 0, should be 2: In scope SELECT h3ToParent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.931540 [ 3830 ] {bee29d8f-60c9-4e88-b46d-eb59aee8cf66} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 0, should be 1: In scope SELECT h3ToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3ToString();) 2025.03.31 19:05:58.932979 [ 3830 ] {bee29d8f-60c9-4e88-b46d-eb59aee8cf66} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 0, should be 1: In scope SELECT h3ToString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.949063 [ 3830 ] {b0376fd0-9477-41d4-918e-1675d048fcf4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 0, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3UnidirectionalEdgeIsValid();) 2025.03.31 19:05:58.950683 [ 3830 ] {b0376fd0-9477-41d4-918e-1675d048fcf4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 0, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:58.967462 [ 3830 ] {353fd826-8cfd-40fb-960b-fe276710cfa1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 0, should be 2: In scope SELECT h3kRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT h3kRing();) 2025.03.31 19:05:58.969080 [ 3830 ] {353fd826-8cfd-40fb-960b-fe276710cfa1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3kRing doesn't match: passed 0, should be 2: In scope SELECT h3kRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.081354 [ 3830 ] {e6c56b44-2fc1-4981-b1b0-d7c344176e1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 0, should be 2: In scope SELECT has(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT has();) 2025.03.31 19:05:59.083052 [ 3830 ] {e6c56b44-2fc1-4981-b1b0-d7c344176e1d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function has doesn't match: passed 0, should be 2: In scope SELECT has(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.135852 [ 3830 ] {a1089103-ba28-4c4b-8f51-d51dc76794e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 0, should be 2: In scope SELECT hasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasAll();) 2025.03.31 19:05:59.137311 [ 3830 ] {a1089103-ba28-4c4b-8f51-d51dc76794e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAll doesn't match: passed 0, should be 2: In scope SELECT hasAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.153375 [ 3830 ] {38969376-4d1b-400e-abfd-86d5ce74cced} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 0, should be 2: In scope SELECT hasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasAny();) 2025.03.31 19:05:59.155070 [ 3830 ] {38969376-4d1b-400e-abfd-86d5ce74cced} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasAny doesn't match: passed 0, should be 2: In scope SELECT hasAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.170257 [ 3830 ] {9d3ca88c-8836-4273-aa5e-0076c50e1c5c} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasColumnInTable();) 2025.03.31 19:05:59.172285 [ 3830 ] {9d3ca88c-8836-4273-aa5e-0076c50e1c5c} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.264884 [ 3830 ] {bed74fbb-08d3-4592-95ad-060d8ae2fe37} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 0, should be 2: In scope SELECT hasSubsequence(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasSubsequence();) 2025.03.31 19:05:59.268790 [ 3830 ] {bed74fbb-08d3-4592-95ad-060d8ae2fe37} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequence doesn't match: passed 0, should be 2: In scope SELECT hasSubsequence(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.283958 [ 3830 ] {31c736bc-bc77-4a7c-a309-e12ea26fe53d} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasSubsequenceCaseInsensitive();) 2025.03.31 19:05:59.285339 [ 3830 ] {31c736bc-bc77-4a7c-a309-e12ea26fe53d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.387413 [ 3830 ] {7baff932-a270-4a8a-a5b2-7deeb34e9550} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8();) 2025.03.31 19:05:59.389176 [ 3830 ] {7baff932-a270-4a8a-a5b2-7deeb34e9550} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.403908 [ 3830 ] {51c12e11-27f8-4add-9142-e4437c9960c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasSubsequenceUTF8();) 2025.03.31 19:05:59.405375 [ 3830 ] {51c12e11-27f8-4add-9142-e4437c9960c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubsequenceUTF8 doesn't match: passed 0, should be 2: In scope SELECT hasSubsequenceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.423108 [ 3830 ] {e259a2ee-5f5f-4149-9131-97155d25790e} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 0, should be 2: In scope SELECT hasSubstr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasSubstr();) 2025.03.31 19:05:59.424783 [ 3830 ] {e259a2ee-5f5f-4149-9131-97155d25790e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasSubstr doesn't match: passed 0, should be 2: In scope SELECT hasSubstr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.468323 [ 3830 ] {c2eaf74e-5801-4f67-9e60-9fc546f974d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 0, should be 2: In scope SELECT hasToken(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasToken();) 2025.03.31 19:05:59.469977 [ 3830 ] {c2eaf74e-5801-4f67-9e60-9fc546f974d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasToken doesn't match: passed 0, should be 2: In scope SELECT hasToken(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.485071 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:05:59.485652 [ 3830 ] {5a09ebde-d499-4aac-91fb-56394d18c9ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasTokenCaseInsensitive();) 2025.03.31 19:05:59.576296 [ 3830 ] {5a09ebde-d499-4aac-91fb-56394d18c9ed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.591251 [ 3830 ] {f4e39266-e1e6-4c26-9e77-f707b6a18ffd} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasTokenCaseInsensitiveOrNull();) 2025.03.31 19:05:59.594073 [ 3830 ] {f4e39266-e1e6-4c26-9e77-f707b6a18ffd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenCaseInsensitiveOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenCaseInsensitiveOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.653845 [ 3830 ] {17d8673e-9309-4b13-bb29-ad19991ad845} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hasTokenOrNull();) 2025.03.31 19:05:59.655259 [ 3830 ] {17d8673e-9309-4b13-bb29-ad19991ad845} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasTokenOrNull doesn't match: passed 0, should be 2: In scope SELECT hasTokenOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.726605 [ 3830 ] {2638da0f-3f4f-4f1a-9a13-6765e47757dd} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 0, should be 1: In scope SELECT hex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hex();) 2025.03.31 19:05:59.728154 [ 3830 ] {2638da0f-3f4f-4f1a-9a13-6765e47757dd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 0, should be 1: In scope SELECT hex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.744225 [ 3830 ] {ba1bc4ab-0ba6-4293-94e5-ef5e55f175a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 0, should be 2: In scope SELECT hilbertDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hilbertDecode();) 2025.03.31 19:05:59.745661 [ 3830 ] {ba1bc4ab-0ba6-4293-94e5-ef5e55f175a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hilbertDecode doesn't match: passed 0, should be 2: In scope SELECT hilbertDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.761686 [ 3830 ] {1f15857f-4958-436d-a3fb-9fe6d649a73a} executeQuery: Code: 35. DB::Exception: At least one UInt argument is required for function hilbertEncode: In scope SELECT hilbertEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hilbertEncode();) 2025.03.31 19:05:59.763692 [ 3830 ] {1f15857f-4958-436d-a3fb-9fe6d649a73a} TCPHandler: Code: 35. DB::Exception: At least one UInt argument is required for function hilbertEncode: In scope SELECT hilbertEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:05:59.841316 [ 3830 ] {a78f997d-a8c7-4f00-ad01-d838f58e1c7e} executeQuery: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT histogram();) 2025.03.31 19:05:59.843021 [ 3830 ] {a78f997d-a8c7-4f00-ad01-d838f58e1c7e} TCPHandler: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.933639 [ 3830 ] {e79c51c5-cfb2-43ec-b00e-e2bea13e1505} executeQuery: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 0, should be 3 or 4: In scope SELECT hop(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hop();) 2025.03.31 19:05:59.935916 [ 3830 ] {e79c51c5-cfb2-43ec-b00e-e2bea13e1505} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 0, should be 3 or 4: In scope SELECT hop(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:05:59.952508 [ 3830 ] {126f3aea-475d-41ab-95aa-7214f3849821} executeQuery: Code: 42. DB::Exception: Number of arguments for function hopEnd doesn't match: passed 0, should be 3 or 4: In scope SELECT hopEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hopEnd();) 2025.03.31 19:05:59.992939 [ 3830 ] {126f3aea-475d-41ab-95aa-7214f3849821} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hopEnd doesn't match: passed 0, should be 3 or 4: In scope SELECT hopEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.009312 [ 3830 ] {38c5a842-4110-4fa6-a5cc-2bdd0236e4af} executeQuery: Code: 42. DB::Exception: Number of arguments for function hopStart doesn't match: passed 0, should be 3 or 4: In scope SELECT hopStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hopStart();) 2025.03.31 19:06:00.011173 [ 3830 ] {38c5a842-4110-4fa6-a5cc-2bdd0236e4af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hopStart doesn't match: passed 0, should be 3 or 4: In scope SELECT hopStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.224090 [ 3830 ] {0c60859f-b956-45d4-8e37-e95714211227} executeQuery: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 0, should be 2: In scope SELECT hypot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT hypot();) 2025.03.31 19:06:00.226376 [ 3830 ] {0c60859f-b956-45d4-8e37-e95714211227} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hypot doesn't match: passed 0, should be 2: In scope SELECT hypot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.243816 [ 3830 ] {07caf7da-de7b-456f-a9cd-3da5bb06f36e} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 0, should be 1: In scope SELECT identity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT identity();) 2025.03.31 19:06:00.245579 [ 3830 ] {07caf7da-de7b-456f-a9cd-3da5bb06f36e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 0, should be 1: In scope SELECT identity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.262677 [ 3830 ] {ae7361f7-f98e-4509-b7a2-9a4697f13636} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 0, should be 1: In scope SELECT idnaDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT idnaDecode();) 2025.03.31 19:06:00.264972 [ 3830 ] {ae7361f7-f98e-4509-b7a2-9a4697f13636} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 0, should be 1: In scope SELECT idnaDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.282123 [ 3830 ] {644eb201-db28-409c-8e2b-5ea2d1e0a16e} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 0, should be 1: In scope SELECT idnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT idnaEncode();) 2025.03.31 19:06:00.283814 [ 3830 ] {644eb201-db28-409c-8e2b-5ea2d1e0a16e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 0, should be 1: In scope SELECT idnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.375222 [ 3830 ] {f263c90d-2410-468b-b345-470990f65c9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 0, should be 3: In scope SELECT if(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT if();) 2025.03.31 19:06:00.376727 [ 3830 ] {f263c90d-2410-468b-b345-470990f65c9c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 0, should be 3: In scope SELECT if(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.391993 [ 3830 ] {c5fafeee-1df6-4743-87a0-07fc5a6a724c} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 0, should be 2: In scope SELECT ifNotFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ifNotFinite();) 2025.03.31 19:06:00.393438 [ 3830 ] {c5fafeee-1df6-4743-87a0-07fc5a6a724c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNotFinite doesn't match: passed 0, should be 2: In scope SELECT ifNotFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.410630 [ 3830 ] {21b00f42-ced1-47d2-bb25-8f0f7689b5d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 0, should be 2: In scope SELECT ifNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ifNull();) 2025.03.31 19:06:00.412372 [ 3830 ] {21b00f42-ced1-47d2-bb25-8f0f7689b5d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ifNull doesn't match: passed 0, should be 2: In scope SELECT ifNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.508276 [ 3830 ] {900dba67-0099-465f-9333-6ee86c2accb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 0, should be 2: In scope SELECT ilike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ilike();) 2025.03.31 19:06:00.509988 [ 3830 ] {900dba67-0099-465f-9333-6ee86c2accb7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ilike doesn't match: passed 0, should be 2: In scope SELECT ilike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.524120 [ 3830 ] {63532691-6ba1-44ed-a099-e57f4de87ccc} executeQuery: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT in();) 2025.03.31 19:06:00.525542 [ 3830 ] {63532691-6ba1-44ed-a099-e57f4de87ccc} TCPHandler: Code: 42. DB::Exception: Function 'in' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.542601 [ 3830 ] {26866a7c-113f-4a8c-92b9-ca3e84aab90b} executeQuery: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT inIgnoreSet();) 2025.03.31 19:06:00.544161 [ 3830 ] {26866a7c-113f-4a8c-92b9-ca3e84aab90b} TCPHandler: Code: 42. DB::Exception: Function 'inIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.587221 [ 3830 ] {b050c5fc-64b4-4ea3-8a85-615e3bd8d731} executeQuery: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 0, should be 2: In scope SELECT indexOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT indexOf();) 2025.03.31 19:06:00.588829 [ 3830 ] {b050c5fc-64b4-4ea3-8a85-615e3bd8d731} TCPHandler: Code: 42. DB::Exception: Number of arguments for function indexOf doesn't match: passed 0, should be 2: In scope SELECT indexOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.596613 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:00.604994 [ 3830 ] {6d8e6739-67a4-4e21-ab44-558ce574fe3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 0, should be 1: In scope SELECT initcap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT initcap();) 2025.03.31 19:06:00.606861 [ 3830 ] {6d8e6739-67a4-4e21-ab44-558ce574fe3a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 0, should be 1: In scope SELECT initcap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.630692 [ 3830 ] {8a8a66dc-b44f-44d8-855d-d1425452463b} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 0, should be 1: In scope SELECT initcapUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT initcapUTF8();) 2025.03.31 19:06:00.632591 [ 3830 ] {8a8a66dc-b44f-44d8-855d-d1425452463b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 0, should be 1: In scope SELECT initcapUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.805895 [ 3830 ] {bb5d4dba-8bb5-4243-b9ad-7e4f54f727d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function initializeAggregation doesn't match: passed 0, should be at least 2.: In scope SELECT initializeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT initializeAggregation();) 2025.03.31 19:06:00.807319 [ 3830 ] {bb5d4dba-8bb5-4243-b9ad-7e4f54f727d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initializeAggregation doesn't match: passed 0, should be at least 2.: In scope SELECT initializeAggregation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.847973 [ 3830 ] {d4d93631-a688-44e4-8710-26f8c965baf2} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT instr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT instr();) 2025.03.31 19:06:00.850147 [ 3830 ] {d4d93631-a688-44e4-8710-26f8c965baf2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT instr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.924334 [ 3830 ] {bb133e2d-2776-419f-b823-72fbb0fd6fea} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 0, should be 2: In scope SELECT intDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intDiv();) 2025.03.31 19:06:00.926390 [ 3830 ] {bb133e2d-2776-419f-b823-72fbb0fd6fea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDiv doesn't match: passed 0, should be 2: In scope SELECT intDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:00.941057 [ 3830 ] {0f5f44b0-de1e-46de-945c-54a5d746389f} executeQuery: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 0, should be 2: In scope SELECT intDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intDivOrZero();) 2025.03.31 19:06:00.942736 [ 3830 ] {0f5f44b0-de1e-46de-945c-54a5d746389f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intDivOrZero doesn't match: passed 0, should be 2: In scope SELECT intDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.021371 [ 3830 ] {43f335e9-ecc9-4504-b9b0-c61ca15cec1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 0, should be 1: In scope SELECT intExp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intExp10();) 2025.03.31 19:06:01.023009 [ 3830 ] {43f335e9-ecc9-4504-b9b0-c61ca15cec1b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 0, should be 1: In scope SELECT intExp10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.038136 [ 3830 ] {612cb38b-259f-41da-bbcd-3e387269ee2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 0, should be 1: In scope SELECT intExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intExp2();) 2025.03.31 19:06:01.039584 [ 3830 ] {612cb38b-259f-41da-bbcd-3e387269ee2b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 0, should be 1: In scope SELECT intExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.054848 [ 3830 ] {9a26b38a-e024-4ca8-a7e0-0e5128815022} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 0, should be 1: In scope SELECT intHash32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intHash32();) 2025.03.31 19:06:01.056259 [ 3830 ] {9a26b38a-e024-4ca8-a7e0-0e5128815022} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 0, should be 1: In scope SELECT intHash32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.071428 [ 3830 ] {da6931c6-b7bd-4cb3-874c-9824014fa872} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 0, should be 1: In scope SELECT intHash64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intHash64();) 2025.03.31 19:06:01.073063 [ 3830 ] {da6931c6-b7bd-4cb3-874c-9824014fa872} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 0, should be 1: In scope SELECT intHash64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.150215 [ 3830 ] {369d6e4b-9b15-4668-95a3-452fbc9cadb5} executeQuery: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT intervalLengthSum();) 2025.03.31 19:06:01.151650 [ 3830 ] {369d6e4b-9b15-4668-95a3-452fbc9cadb5} TCPHandler: Code: 42. DB::Exception: Aggregate function intervalLengthSum requires two timestamps argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.167473 [ 3830 ] {783eacbe-a9f4-4dd8-be29-6620025248a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 0, should be 1: In scope SELECT isConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isConstant();) 2025.03.31 19:06:01.169056 [ 3830 ] {783eacbe-a9f4-4dd8-be29-6620025248a6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 0, should be 1: In scope SELECT isConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.185694 [ 3830 ] {5a6babaf-78d9-43e3-ba1d-74ebfc990751} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 0, should be 1 or 2.: In scope SELECT isDecimalOverflow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isDecimalOverflow();) 2025.03.31 19:06:01.187543 [ 3830 ] {5a6babaf-78d9-43e3-ba1d-74ebfc990751} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDecimalOverflow doesn't match: passed 0, should be 1 or 2.: In scope SELECT isDecimalOverflow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.191539 [ 4240 ] {d931f48a-6320-40b8-b1d8-34195f72c0e9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39490) (comment: 02473_optimize_old_parts.sh) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_with_merge_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:06:01.194137 [ 4240 ] {d931f48a-6320-40b8-b1d8-34195f72c0e9} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:06:01.203677 [ 3830 ] {69979ec8-1154-493c-8459-add0492b92fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 0, should be 1: In scope SELECT isDynamicElementInSharedData(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isDynamicElementInSharedData();) 2025.03.31 19:06:01.205428 [ 3830 ] {69979ec8-1154-493c-8459-add0492b92fe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 0, should be 1: In scope SELECT isDynamicElementInSharedData(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.220629 [ 3830 ] {f241b89e-12c8-492d-b4da-1a085d8cc8ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 0, should be 1: In scope SELECT isFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isFinite();) 2025.03.31 19:06:01.222205 [ 3830 ] {f241b89e-12c8-492d-b4da-1a085d8cc8ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 0, should be 1: In scope SELECT isFinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.236719 [ 3830 ] {3b200b89-00b2-4044-9af5-6473a6e6e582} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 0, should be 2: In scope SELECT isIPAddressInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isIPAddressInRange();) 2025.03.31 19:06:01.308723 [ 3830 ] {3b200b89-00b2-4044-9af5-6473a6e6e582} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPAddressInRange doesn't match: passed 0, should be 2: In scope SELECT isIPAddressInRange(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.323657 [ 3830 ] {92ae6528-7151-420f-9bb4-9f5cf2c4d804} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 0, should be 1: In scope SELECT isIPv4String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isIPv4String();) 2025.03.31 19:06:01.325050 [ 3830 ] {92ae6528-7151-420f-9bb4-9f5cf2c4d804} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 0, should be 1: In scope SELECT isIPv4String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.339868 [ 3830 ] {5294049f-7ad1-407a-953d-3fee65f72225} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 0, should be 1: In scope SELECT isIPv6String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isIPv6String();) 2025.03.31 19:06:01.341512 [ 3830 ] {5294049f-7ad1-407a-953d-3fee65f72225} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 0, should be 1: In scope SELECT isIPv6String(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.414637 [ 3830 ] {c6a37ad9-4104-460b-89a3-ad9c98b5ea17} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 0, should be 1: In scope SELECT isInfinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isInfinite();) 2025.03.31 19:06:01.416242 [ 3830 ] {c6a37ad9-4104-460b-89a3-ad9c98b5ea17} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 0, should be 1: In scope SELECT isInfinite(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.431269 [ 3830 ] {5ad12c1e-ceda-4fd8-86eb-e3afb13d05fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 0, should be 1: In scope SELECT isNaN(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isNaN();) 2025.03.31 19:06:01.432684 [ 3830 ] {5ad12c1e-ceda-4fd8-86eb-e3afb13d05fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 0, should be 1: In scope SELECT isNaN(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.542625 [ 3830 ] {5ebcb490-4dac-4970-8d4b-21969214034d} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 0, should be 2: In scope SELECT isNotDistinctFrom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isNotDistinctFrom();) 2025.03.31 19:06:01.544296 [ 3830 ] {5ebcb490-4dac-4970-8d4b-21969214034d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotDistinctFrom doesn't match: passed 0, should be 2: In scope SELECT isNotDistinctFrom(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.559879 [ 3830 ] {2b45c134-9e64-45ff-8d68-ece28cd62c87} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 0, should be 1: In scope SELECT isNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isNotNull();) 2025.03.31 19:06:01.561414 [ 3830 ] {2b45c134-9e64-45ff-8d68-ece28cd62c87} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 0, should be 1: In scope SELECT isNotNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.576857 [ 3830 ] {0689b684-356d-4601-bfd5-0f3a773a93f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 0, should be 1: In scope SELECT isNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isNull();) 2025.03.31 19:06:01.578801 [ 3830 ] {0689b684-356d-4601-bfd5-0f3a773a93f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 0, should be 1: In scope SELECT isNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.594733 [ 3830 ] {c7328bca-c9fc-4348-b661-210e12a3a204} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 0, should be 1: In scope SELECT isNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isNullable();) 2025.03.31 19:06:01.596374 [ 3830 ] {c7328bca-c9fc-4348-b661-210e12a3a204} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 0, should be 1: In scope SELECT isNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.612285 [ 3830 ] {a9284854-a7d9-4f3b-bb43-54bbdff2e940} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isValidJSON();) 2025.03.31 19:06:01.614035 [ 3830 ] {a9284854-a7d9-4f3b-bb43-54bbdff2e940} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.630155 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:01.630625 [ 3830 ] {99613ced-ca83-4ef1-9388-0f71beb35d1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT isValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isValidUTF8();) 2025.03.31 19:06:01.632148 [ 3830 ] {99613ced-ca83-4ef1-9388-0f71beb35d1d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT isValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.647084 [ 3830 ] {1339f69e-f3c1-4bae-8c5f-0586e481dd73} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 0, should be 1: In scope SELECT isZeroOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT isZeroOrNull();) 2025.03.31 19:06:01.648590 [ 3830 ] {1339f69e-f3c1-4bae-8c5f-0586e481dd73} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 0, should be 1: In scope SELECT isZeroOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.663640 [ 3830 ] {b62c0667-1218-4c73-a118-e2cdcec27b19} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT jaroSimilarity();) 2025.03.31 19:06:01.665204 [ 3830 ] {b62c0667-1218-4c73-a118-e2cdcec27b19} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.680535 [ 3830 ] {2179e8fd-fe0b-4d37-9803-905a7d7ef779} executeQuery: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroWinklerSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT jaroWinklerSimilarity();) 2025.03.31 19:06:01.682236 [ 3830 ] {2179e8fd-fe0b-4d37-9803-905a7d7ef779} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jaroWinklerSimilarity doesn't match: passed 0, should be 2: In scope SELECT jaroWinklerSimilarity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.891942 [ 3830 ] {297485dd-20b2-404b-8d94-8a85f7da3566} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT joinGet();) 2025.03.31 19:06:01.893665 [ 3830 ] {297485dd-20b2-404b-8d94-8a85f7da3566} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGet(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.909618 [ 3830 ] {d0358360-c6dd-4f2e-acf0-2fefc9793975} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT joinGetOrNull();) 2025.03.31 19:06:01.911437 [ 3830 ] {d0358360-c6dd-4f2e-acf0-2fefc9793975} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 0, should be greater or equal to 3: In scope SELECT joinGetOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.927102 [ 3830 ] {130527e5-0123-458b-b3df-ca0b4ed1e7b7} executeQuery: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT jsonMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT jsonMergePatch();) 2025.03.31 19:06:01.929032 [ 3830 ] {130527e5-0123-458b-b3df-ca0b4ed1e7b7} TCPHandler: Code: 35. DB::Exception: Function JSONMergePatch requires at least one argument.: In scope SELECT jsonMergePatch(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:01.944280 [ 3830 ] {952e0452-2226-412d-bfcd-3204a35e5b25} executeQuery: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 0, should be 2: In scope SELECT jumpConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT jumpConsistentHash();) 2025.03.31 19:06:01.945877 [ 3830 ] {952e0452-2226-412d-bfcd-3204a35e5b25} TCPHandler: Code: 42. DB::Exception: Number of arguments for function jumpConsistentHash doesn't match: passed 0, should be 2: In scope SELECT jumpConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:01.985041 [ 3830 ] {7d755267-3524-4cec-bb63-0b58f542317f} executeQuery: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kolmogorovSmirnovTest();) 2025.03.31 19:06:01.986707 [ 3830 ] {7d755267-3524-4cec-bb63-0b58f542317f} TCPHandler: Code: 42. DB::Exception: Aggregate function kolmogorovSmirnovTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.002086 [ 3830 ] {e2da6036-e97f-4f8e-851a-caafe1a5ff9f} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT kostikConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kostikConsistentHash();) 2025.03.31 19:06:02.003594 [ 3830 ] {e2da6036-e97f-4f8e-851a-caafe1a5ff9f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT kostikConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.018453 [ 3830 ] {f018513b-0527-49ba-9453-ebbef79549b6} executeQuery: Code: 35. DB::Exception: Function kql_array_sort_asc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_asc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kql_array_sort_asc();) 2025.03.31 19:06:02.020026 [ 3830 ] {f018513b-0527-49ba-9453-ebbef79549b6} TCPHandler: Code: 35. DB::Exception: Function kql_array_sort_asc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_asc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:02.036184 [ 3830 ] {7710bf4a-ae18-455e-818f-d7e9ea663950} executeQuery: Code: 35. DB::Exception: Function kql_array_sort_desc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_desc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kql_array_sort_desc();) 2025.03.31 19:06:02.038041 [ 3830 ] {7710bf4a-ae18-455e-818f-d7e9ea663950} TCPHandler: Code: 35. DB::Exception: Function kql_array_sort_desc needs at least one argument; passed 0.: In scope SELECT kql_array_sort_desc(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:02.053836 [ 3830 ] {1ffba67f-d74f-4317-b032-6a4dd1ca6636} executeQuery: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kurtPop();) 2025.03.31 19:06:02.055511 [ 3830 ] {1ffba67f-d74f-4317-b032-6a4dd1ca6636} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.071651 [ 3830 ] {5054556c-2b91-4091-a21a-4fdda97d2fdd} executeQuery: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT kurtSamp();) 2025.03.31 19:06:02.073440 [ 3830 ] {5054556c-2b91-4091-a21a-4fdda97d2fdd} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.165567 [ 3830 ] {0186d853-d0cc-4ce7-84a4-effc50f96001} executeQuery: Code: 35. DB::Exception: Function lagInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lagInFrame();) 2025.03.31 19:06:02.167591 [ 3830 ] {0186d853-d0cc-4ce7-84a4-effc50f96001} TCPHandler: Code: 35. DB::Exception: Function lagInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:02.184499 [ 3830 ] {470281d7-efc9-4877-9fda-948189572f9a} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT largestTriangleThreeBuckets();) 2025.03.31 19:06:02.186101 [ 3830 ] {470281d7-efc9-4877-9fda-948189572f9a} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.202761 [ 3830 ] {92d2257f-2694-4ca4-9163-b2a16c77a18b} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT last_value();) 2025.03.31 19:06:02.204312 [ 3830 ] {92d2257f-2694-4ca4-9163-b2a16c77a18b} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.219755 [ 3830 ] {d9e52358-15e8-4ad9-bcb0-46f909a360f9} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT last_value_respect_nulls();) 2025.03.31 19:06:02.221296 [ 3830 ] {d9e52358-15e8-4ad9-bcb0-46f909a360f9} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.238603 [ 3830 ] {face6db1-c202-4b5e-b6e8-f91e4b52debd} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lcase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lcase();) 2025.03.31 19:06:02.240540 [ 3830 ] {face6db1-c202-4b5e-b6e8-f91e4b52debd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lcase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.257457 [ 3830 ] {7c2d77cf-7493-46b0-ba46-dc311468ecf9} executeQuery: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 0, should be 2: In scope SELECT lcm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lcm();) 2025.03.31 19:06:02.259591 [ 3830 ] {7c2d77cf-7493-46b0-ba46-dc311468ecf9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lcm doesn't match: passed 0, should be 2: In scope SELECT lcm(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.276267 [ 3830 ] {933e4094-a2d8-42e9-ba43-50e751714b67} executeQuery: Code: 35. DB::Exception: Function leadInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT leadInFrame();) 2025.03.31 19:06:02.278029 [ 3830 ] {933e4094-a2d8-42e9-ba43-50e751714b67} TCPHandler: Code: 35. DB::Exception: Function leadInFrame takes at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:02.292999 [ 3830 ] {868438fb-27b2-4715-a4ea-41dd5bbd687f} executeQuery: Code: 42. DB::Exception: Function least cannot be called without arguments: In scope SELECT least(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT least();) 2025.03.31 19:06:02.294566 [ 3830 ] {868438fb-27b2-4715-a4ea-41dd5bbd687f} TCPHandler: Code: 42. DB::Exception: Function least cannot be called without arguments: In scope SELECT least(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.309927 [ 3830 ] {bb1582db-44d2-4d9a-8c9b-6f26981bb339} executeQuery: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 0, should be 2: In scope SELECT left(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT left();) 2025.03.31 19:06:02.311448 [ 3830 ] {bb1582db-44d2-4d9a-8c9b-6f26981bb339} TCPHandler: Code: 42. DB::Exception: Number of arguments for function left doesn't match: passed 0, should be 2: In scope SELECT left(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.327420 [ 3830 ] {e0b4667d-c2cd-46c4-9093-c92ecee23a97} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT leftPad();) 2025.03.31 19:06:02.328763 [ 3830 ] {e0b4667d-c2cd-46c4-9093-c92ecee23a97} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.345313 [ 3830 ] {a9f459b2-0599-4028-88cd-40befd2af608} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT leftPadUTF8();) 2025.03.31 19:06:02.347382 [ 3830 ] {a9f459b2-0599-4028-88cd-40befd2af608} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT leftPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.364099 [ 3830 ] {1521683a-b60d-4688-9320-3d105fe3fd30} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 0, should be 2: In scope SELECT leftUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT leftUTF8();) 2025.03.31 19:06:02.366064 [ 3830 ] {1521683a-b60d-4688-9320-3d105fe3fd30} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftUTF8 doesn't match: passed 0, should be 2: In scope SELECT leftUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.381621 [ 3830 ] {fbc1a5d5-192e-440d-8552-39155d7ad717} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lemmatize();) 2025.03.31 19:06:02.383261 [ 3830 ] {fbc1a5d5-192e-440d-8552-39155d7ad717} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:06:02.400494 [ 3830 ] {eaeafe4b-8b3a-4535-bbc9-e04b5f8df429} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT length(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT length();) 2025.03.31 19:06:02.402452 [ 3830 ] {eaeafe4b-8b3a-4535-bbc9-e04b5f8df429} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 0, should be 1: In scope SELECT length(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.418110 [ 3830 ] {13aa8300-b8e6-46f5-9478-ab882f35eb64} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT lengthUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lengthUTF8();) 2025.03.31 19:06:02.419854 [ 3830 ] {13aa8300-b8e6-46f5-9478-ab882f35eb64} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 0, should be 1: In scope SELECT lengthUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.436611 [ 3830 ] {982da7c2-5a07-441b-9557-0f488ef9725f} executeQuery: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 0, should be 2: In scope SELECT less(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT less();) 2025.03.31 19:06:02.438500 [ 3830 ] {982da7c2-5a07-441b-9557-0f488ef9725f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function less doesn't match: passed 0, should be 2: In scope SELECT less(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.455513 [ 3830 ] {b155ec73-0d97-4874-84c7-0b84d98d5606} executeQuery: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 0, should be 2: In scope SELECT lessOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lessOrEquals();) 2025.03.31 19:06:02.457419 [ 3830 ] {b155ec73-0d97-4874-84c7-0b84d98d5606} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lessOrEquals doesn't match: passed 0, should be 2: In scope SELECT lessOrEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.474669 [ 3830 ] {05b33db7-9bb8-46d8-9b4f-313c9fd32532} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT levenshteinDistance();) 2025.03.31 19:06:02.476393 [ 3830 ] {05b33db7-9bb8-46d8-9b4f-313c9fd32532} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistance doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.492724 [ 3830 ] {b4756f7f-9222-49b4-b5be-ffed751e52c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT levenshteinDistanceUTF8();) 2025.03.31 19:06:02.494347 [ 3830 ] {b4756f7f-9222-49b4-b5be-ffed751e52c6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function editDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT levenshteinDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.510884 [ 3830 ] {cf075691-48df-474b-9b5c-044ddd48a20b} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 0, should be 1: In scope SELECT lgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lgamma();) 2025.03.31 19:06:02.512616 [ 3830 ] {cf075691-48df-474b-9b5c-044ddd48a20b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 0, should be 1: In scope SELECT lgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.528149 [ 3830 ] {f88436ec-6204-47d6-81d1-c95ec3b37db2} executeQuery: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 0, should be 2: In scope SELECT like(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT like();) 2025.03.31 19:06:02.529948 [ 3830 ] {f88436ec-6204-47d6-81d1-c95ec3b37db2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function like doesn't match: passed 0, should be 2: In scope SELECT like(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.545560 [ 3830 ] {9790ba6c-9597-4131-8d54-fefe5e53cb15} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT ln(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ln();) 2025.03.31 19:06:02.547253 [ 3830 ] {9790ba6c-9597-4131-8d54-fefe5e53cb15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT ln(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.605443 [ 3830 ] {88873b4a-b988-4472-8d88-0589687f8e4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 0, should be 2 or 3: In scope SELECT locate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT locate();) 2025.03.31 19:06:02.607081 [ 3830 ] {88873b4a-b988-4472-8d88-0589687f8e4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 0, should be 2 or 3: In scope SELECT locate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.623188 [ 3830 ] {a3782ff7-ccf2-4ecf-af8d-aeadf7bb861d} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT log(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT log();) 2025.03.31 19:06:02.624897 [ 3830 ] {a3782ff7-ccf2-4ecf-af8d-aeadf7bb861d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 0, should be 1: In scope SELECT log(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.638691 [ 3830 ] {48b9b2aa-159c-4c8e-ac58-3561adb76a78} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 0, should be 1: In scope SELECT log10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT log10();) 2025.03.31 19:06:02.642652 [ 3830 ] {48b9b2aa-159c-4c8e-ac58-3561adb76a78} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 0, should be 1: In scope SELECT log10(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.655309 [ 3830 ] {94b41e08-02cf-4fb5-b25b-1393445a6830} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 0, should be 1: In scope SELECT log1p(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT log1p();) 2025.03.31 19:06:02.666416 [ 3830 ] {94b41e08-02cf-4fb5-b25b-1393445a6830} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 0, should be 1: In scope SELECT log1p(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.666605 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:02.680426 [ 3830 ] {bcbd6ba6-5548-44ef-bbad-a99141536257} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 0, should be 1: In scope SELECT log2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT log2();) 2025.03.31 19:06:02.682039 [ 3830 ] {bcbd6ba6-5548-44ef-bbad-a99141536257} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 0, should be 1: In scope SELECT log2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.696850 [ 3830 ] {306636dc-0c7b-4d01-b9e3-efb246e3a8ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 0, should be 1: In scope SELECT logTrace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT logTrace();) 2025.03.31 19:06:02.698600 [ 3830 ] {306636dc-0c7b-4d01-b9e3-efb246e3a8ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 0, should be 1: In scope SELECT logTrace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.751776 [ 3830 ] {8849986f-bd62-4ef8-b26a-433cce96bfbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lowCardinalityIndices();) 2025.03.31 19:06:02.753445 [ 3830 ] {8849986f-bd62-4ef8-b26a-433cce96bfbe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.769237 [ 3830 ] {ea8a4bed-5ff0-4adf-83b4-2b217cab6e60} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lowCardinalityKeys();) 2025.03.31 19:06:02.770954 [ 3830 ] {ea8a4bed-5ff0-4adf-83b4-2b217cab6e60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 0, should be 1: In scope SELECT lowCardinalityKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.869028 [ 3830 ] {b41b34ea-ffaa-480b-ba6d-6e23d1d9ee0a} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lower(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lower();) 2025.03.31 19:06:02.870642 [ 3830 ] {b41b34ea-ffaa-480b-ba6d-6e23d1d9ee0a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 0, should be 1: In scope SELECT lower(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.885861 [ 3830 ] {5980a4e6-df75-4150-9ae8-c21f667ca014} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 0, should be 1: In scope SELECT lowerUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lowerUTF8();) 2025.03.31 19:06:02.887386 [ 3830 ] {5980a4e6-df75-4150-9ae8-c21f667ca014} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 0, should be 1: In scope SELECT lowerUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:02.902668 [ 3830 ] {29632eb0-5e5b-4828-9304-239c703de9c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT lpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lpad();) 2025.03.31 19:06:02.904146 [ 3830 ] {29632eb0-5e5b-4828-9304-239c703de9c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function leftPad doesn't match: passed 0, should be 2 or 3: In scope SELECT lpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.005331 [ 3830 ] {2cbe330a-ff54-4934-8426-d578ed948b50} executeQuery: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT lttb();) 2025.03.31 19:06:03.062803 [ 3830 ] {2cbe330a-ff54-4934-8426-d578ed948b50} TCPHandler: Code: 42. DB::Exception: Aggregate function largestTriangleThreeBuckets requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.078150 [ 3830 ] {e1235e7d-32e5-4fe7-8dbd-2b8a1a815772} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT makeDate();) 2025.03.31 19:06:03.079650 [ 3830 ] {e1235e7d-32e5-4fe7-8dbd-2b8a1a815772} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.094062 [ 3830 ] {a62129ff-bb28-4bad-a64c-f7cb882c7657} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT makeDate32();) 2025.03.31 19:06:03.095537 [ 3830 ] {a62129ff-bb28-4bad-a64c-f7cb882c7657} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 0 arguments: In scope SELECT makeDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.111422 [ 3830 ] {88f98c22-017e-48e8-969d-002a25c94713} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT makeDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT makeDateTime();) 2025.03.31 19:06:03.112987 [ 3830 ] {88f98c22-017e-48e8-969d-002a25c94713} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT makeDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.127402 [ 3830 ] {852b7af0-f20e-4ad9-b00a-93fca9e3753f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 0 arguments: In scope SELECT makeDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT makeDateTime64();) 2025.03.31 19:06:03.128792 [ 3830 ] {852b7af0-f20e-4ad9-b00a-93fca9e3753f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 0 arguments: In scope SELECT makeDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.142888 [ 3830 ] {916bdbfa-e609-48b1-aea0-99bad7f97df3} executeQuery: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mannWhitneyUTest();) 2025.03.31 19:06:03.144421 [ 3830 ] {916bdbfa-e609-48b1-aea0-99bad7f97df3} TCPHandler: Code: 42. DB::Exception: Aggregate function mannWhitneyUTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.243362 [ 3830 ] {1ccadf82-06d0-4a32-b58e-4e494a457778} executeQuery: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapAdd();) 2025.03.31 19:06:03.244692 [ 3830 ] {1ccadf82-06d0-4a32-b58e-4e494a457778} TCPHandler: Code: 42. DB::Exception: mapAdd accepts at least two maps or map tuples: In scope SELECT mapAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.257407 [ 3830 ] {f4ceb667-1b98-44dd-a957-344c95116c17} executeQuery: Code: 42. DB::Exception: Function mapAll requires at least one argument, passed 0: In scope SELECT mapAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapAll();) 2025.03.31 19:06:03.258895 [ 3830 ] {f4ceb667-1b98-44dd-a957-344c95116c17} TCPHandler: Code: 42. DB::Exception: Function mapAll requires at least one argument, passed 0: In scope SELECT mapAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.273401 [ 3830 ] {87c183ba-094f-4dce-a950-339cf28c1eb2} executeQuery: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapApply();) 2025.03.31 19:06:03.274879 [ 3830 ] {87c183ba-094f-4dce-a950-339cf28c1eb2} TCPHandler: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.289088 [ 3830 ] {188de82b-48ac-46a5-a5df-1cdeff8aea4b} executeQuery: Code: 42. DB::Exception: Function mapConcat requires at least one argument, passed 0: In scope SELECT mapConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapConcat();) 2025.03.31 19:06:03.290714 [ 3830 ] {188de82b-48ac-46a5-a5df-1cdeff8aea4b} TCPHandler: Code: 42. DB::Exception: Function mapConcat requires at least one argument, passed 0: In scope SELECT mapConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.304866 [ 3830 ] {b7d4d720-96e8-4b62-988f-6c1ef1527f7f} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 0, should be 2: In scope SELECT mapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapContains();) 2025.03.31 19:06:03.306278 [ 3830 ] {b7d4d720-96e8-4b62-988f-6c1ef1527f7f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapContains doesn't match: passed 0, should be 2: In scope SELECT mapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.330685 [ 3830 ] {ce6de056-93a3-4cf7-bcf5-1e6a1cead862} executeQuery: Code: 42. DB::Exception: Function mapContainsKeyLike requires at least one argument, passed 0: In scope SELECT mapContainsKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapContainsKeyLike();) 2025.03.31 19:06:03.332205 [ 3830 ] {ce6de056-93a3-4cf7-bcf5-1e6a1cead862} TCPHandler: Code: 42. DB::Exception: Function mapContainsKeyLike requires at least one argument, passed 0: In scope SELECT mapContainsKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.348665 [ 3830 ] {d411095f-896e-487b-a97b-1d7b99dafc1a} executeQuery: Code: 42. DB::Exception: Function mapExists requires at least one argument, passed 0: In scope SELECT mapExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapExists();) 2025.03.31 19:06:03.350708 [ 3830 ] {d411095f-896e-487b-a97b-1d7b99dafc1a} TCPHandler: Code: 42. DB::Exception: Function mapExists requires at least one argument, passed 0: In scope SELECT mapExists(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.365816 [ 3830 ] {c02a5e89-a6d0-4a8a-b145-cccd9a34ab06} executeQuery: Code: 42. DB::Exception: Function mapExtractKeyLike requires at least one argument, passed 0: In scope SELECT mapExtractKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapExtractKeyLike();) 2025.03.31 19:06:03.367553 [ 3830 ] {c02a5e89-a6d0-4a8a-b145-cccd9a34ab06} TCPHandler: Code: 42. DB::Exception: Function mapExtractKeyLike requires at least one argument, passed 0: In scope SELECT mapExtractKeyLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.385207 [ 3830 ] {6ca455fd-3bdb-44cf-80cb-2a316874cd97} executeQuery: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapFilter();) 2025.03.31 19:06:03.387204 [ 3830 ] {6ca455fd-3bdb-44cf-80cb-2a316874cd97} TCPHandler: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.401185 [ 3830 ] {8a8e6653-6c7f-4ce2-b13c-f19e497402df} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT mapFromArrays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapFromArrays();) 2025.03.31 19:06:03.402897 [ 3830 ] {8a8e6653-6c7f-4ce2-b13c-f19e497402df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapFromArrays doesn't match: passed 0, should be 2: In scope SELECT mapFromArrays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.417192 [ 3830 ] {2a89c195-4d9c-4bb5-b5d9-5867ae436fae} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT mapFromString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapFromString();) 2025.03.31 19:06:03.418786 [ 3830 ] {2a89c195-4d9c-4bb5-b5d9-5867ae436fae} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT mapFromString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.432382 [ 3830 ] {b15d4751-b2a8-4e3c-b359-c37b0ef950fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 0, should be 1: In scope SELECT mapKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapKeys();) 2025.03.31 19:06:03.433858 [ 3830 ] {b15d4751-b2a8-4e3c-b359-c37b0ef950fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 0, should be 1: In scope SELECT mapKeys(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.450367 [ 3830 ] {dce473a6-3773-499e-b214-6bc78ba3cf68} executeQuery: Code: 42. DB::Exception: Function mapPartialReverseSort requires at least one argument, passed 0: In scope SELECT mapPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapPartialReverseSort();) 2025.03.31 19:06:03.452169 [ 3830 ] {dce473a6-3773-499e-b214-6bc78ba3cf68} TCPHandler: Code: 42. DB::Exception: Function mapPartialReverseSort requires at least one argument, passed 0: In scope SELECT mapPartialReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.470276 [ 3830 ] {1ca78f96-b0c8-4366-a5ac-8716393658a4} executeQuery: Code: 42. DB::Exception: Function mapPartialSort requires at least one argument, passed 0: In scope SELECT mapPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapPartialSort();) 2025.03.31 19:06:03.472351 [ 3830 ] {1ca78f96-b0c8-4366-a5ac-8716393658a4} TCPHandler: Code: 42. DB::Exception: Function mapPartialSort requires at least one argument, passed 0: In scope SELECT mapPartialSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.486819 [ 3830 ] {844e4196-4ce6-422b-827e-911a24bccd2b} executeQuery: Code: 42. DB::Exception: Function mapPopulateSeries accepts at least one map or two arrays arguments, and optional max key argument: In scope SELECT mapPopulateSeries(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapPopulateSeries();) 2025.03.31 19:06:03.488187 [ 3830 ] {844e4196-4ce6-422b-827e-911a24bccd2b} TCPHandler: Code: 42. DB::Exception: Function mapPopulateSeries accepts at least one map or two arrays arguments, and optional max key argument: In scope SELECT mapPopulateSeries(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.503949 [ 3830 ] {bbd9d915-53e2-4768-b687-5f5587bb518e} executeQuery: Code: 42. DB::Exception: Function mapReverseSort requires at least one argument, passed 0: In scope SELECT mapReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapReverseSort();) 2025.03.31 19:06:03.505447 [ 3830 ] {bbd9d915-53e2-4768-b687-5f5587bb518e} TCPHandler: Code: 42. DB::Exception: Function mapReverseSort requires at least one argument, passed 0: In scope SELECT mapReverseSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.520787 [ 3830 ] {84987e67-ea73-4aeb-9b55-f3904aa71968} executeQuery: Code: 42. DB::Exception: Function mapSort requires at least one argument, passed 0: In scope SELECT mapSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapSort();) 2025.03.31 19:06:03.522648 [ 3830 ] {84987e67-ea73-4aeb-9b55-f3904aa71968} TCPHandler: Code: 42. DB::Exception: Function mapSort requires at least one argument, passed 0: In scope SELECT mapSort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.549199 [ 3830 ] {874b2a20-ac5b-4ec2-a219-1f0a9554a897} executeQuery: Code: 42. DB::Exception: mapSubtract accepts at least two maps or map tuples: In scope SELECT mapSubtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapSubtract();) 2025.03.31 19:06:03.550707 [ 3830 ] {874b2a20-ac5b-4ec2-a219-1f0a9554a897} TCPHandler: Code: 42. DB::Exception: mapSubtract accepts at least two maps or map tuples: In scope SELECT mapSubtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.565507 [ 3830 ] {1d3a6a1e-2561-4f9c-8198-b82e2a845a64} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapUpdate();) 2025.03.31 19:06:03.566957 [ 3830 ] {1d3a6a1e-2561-4f9c-8198-b82e2a845a64} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.582453 [ 3830 ] {3f10da6a-1535-4a54-8015-38795304a311} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 0, should be 1: In scope SELECT mapValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mapValues();) 2025.03.31 19:06:03.583846 [ 3830 ] {3f10da6a-1535-4a54-8015-38795304a311} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 0, should be 1: In scope SELECT mapValues(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.600181 [ 3830 ] {ed38c0c8-1577-4a4e-ad83-ad76af886963} executeQuery: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT match(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT match();) 2025.03.31 19:06:03.601694 [ 3830 ] {ed38c0c8-1577-4a4e-ad83-ad76af886963} TCPHandler: Code: 42. DB::Exception: Number of arguments for function match doesn't match: passed 0, should be 2: In scope SELECT match(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.618241 [ 3830 ] {4d37432b-24dc-4d1d-aeb8-176dcf495e94} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 0, should be 1: In scope SELECT materialize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT materialize();) 2025.03.31 19:06:03.619772 [ 3830 ] {4d37432b-24dc-4d1d-aeb8-176dcf495e94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 0, should be 1: In scope SELECT materialize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.635336 [ 3830 ] {15b85867-c5df-47b2-b3ed-eca6b38ea533} executeQuery: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT max();) 2025.03.31 19:06:03.636737 [ 3830 ] {15b85867-c5df-47b2-b3ed-eca6b38ea533} TCPHandler: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.650921 [ 3830 ] {968d7fcb-3db2-4cb8-9ed7-5c55e254b857} executeQuery: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 0, should be 2: In scope SELECT max2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT max2();) 2025.03.31 19:06:03.652306 [ 3830 ] {968d7fcb-3db2-4cb8-9ed7-5c55e254b857} TCPHandler: Code: 42. DB::Exception: Number of arguments for function max2 doesn't match: passed 0, should be 2: In scope SELECT max2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.667239 [ 3830 ] {3f076ef6-45ac-4b49-9062-6d1d9d63d00e} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT maxIntersections();) 2025.03.31 19:06:03.668866 [ 3830 ] {3f076ef6-45ac-4b49-9062-6d1d9d63d00e} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersections requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.684203 [ 3830 ] {4a1d51cd-06af-4e98-8dc9-fff91b92e17b} executeQuery: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT maxIntersectionsPosition();) 2025.03.31 19:06:03.685619 [ 3830 ] {4a1d51cd-06af-4e98-8dc9-fff91b92e17b} TCPHandler: Code: 42. DB::Exception: Aggregate function maxIntersectionsPosition requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.728201 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:03.740897 [ 3830 ] {d0a0dfd8-2dbc-4777-ae01-1cf629eed1d3} executeQuery: Code: 42. DB::Exception: Aggregate function maxMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT maxMappedArrays();) 2025.03.31 19:06:03.742884 [ 3830 ] {d0a0dfd8-2dbc-4777-ae01-1cf629eed1d3} TCPHandler: Code: 42. DB::Exception: Aggregate function maxMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.823840 [ 3830 ] {c28ec59a-8f05-43aa-a54d-a9e1a5f41e1f} executeQuery: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT meanZTest();) 2025.03.31 19:06:03.825366 [ 3830 ] {c28ec59a-8f05-43aa-a54d-a9e1a5f41e1f} TCPHandler: Code: 42. DB::Exception: Aggregate function meanZTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.841656 [ 3830 ] {32662890-ad7f-497f-a7bc-6bb821b9436b} executeQuery: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT median();) 2025.03.31 19:06:03.843601 [ 3830 ] {32662890-ad7f-497f-a7bc-6bb821b9436b} TCPHandler: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:03.934693 [ 3830 ] {b223bc69-c6cd-43b9-8246-bfc089f75229} executeQuery: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianBFloat16();) 2025.03.31 19:06:03.936767 [ 3830 ] {b223bc69-c6cd-43b9-8246-bfc089f75229} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:03.953430 [ 3830 ] {908197ae-db10-4305-9956-ebc9174eb9c1} executeQuery: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianBFloat16Weighted();) 2025.03.31 19:06:03.955443 [ 3830 ] {908197ae-db10-4305-9956-ebc9174eb9c1} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:03.972749 [ 3830 ] {c6374f55-e2bc-472d-92e6-ac85029bea2d} executeQuery: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianDD();) 2025.03.31 19:06:03.974476 [ 3830 ] {c6374f55-e2bc-472d-92e6-ac85029bea2d} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:03.991416 [ 3830 ] {feedd723-9318-44fa-a15a-4cc892feca37} executeQuery: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianDeterministic();) 2025.03.31 19:06:03.992929 [ 3830 ] {feedd723-9318-44fa-a15a-4cc892feca37} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.007654 [ 3830 ] {c4ece650-5094-406f-ade4-76418d35f835} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianExact();) 2025.03.31 19:06:04.009194 [ 3830 ] {c4ece650-5094-406f-ade4-76418d35f835} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.024487 [ 3830 ] {b4cdfdbd-688d-4735-8e69-3678e44779d8} executeQuery: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianExactHigh();) 2025.03.31 19:06:04.038145 [ 3830 ] {b4cdfdbd-688d-4735-8e69-3678e44779d8} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:04.054606 [ 3830 ] {6478f65a-1b61-4cf3-92c5-cb31c195820e} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianExactLow();) 2025.03.31 19:06:04.056335 [ 3830 ] {6478f65a-1b61-4cf3-92c5-cb31c195820e} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.072490 [ 3830 ] {d7fa9f42-049c-415b-8450-16b837bc31d1} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianExactWeighted();) 2025.03.31 19:06:04.074331 [ 3830 ] {d7fa9f42-049c-415b-8450-16b837bc31d1} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.090284 [ 3830 ] {56e7f18e-f98a-49f2-a6fd-df879f8e11b0} executeQuery: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianGK();) 2025.03.31 19:06:04.091995 [ 3830 ] {56e7f18e-f98a-49f2-a6fd-df879f8e11b0} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.143206 [ 3830 ] {c50148d2-0b71-4fe9-ae25-02caa5e8c831} executeQuery: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianInterpolatedWeighted();) 2025.03.31 19:06:04.144691 [ 3830 ] {c50148d2-0b71-4fe9-ae25-02caa5e8c831} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.158839 [ 3830 ] {188e2d88-0797-499e-9349-d197a358a7c1} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianTDigest();) 2025.03.31 19:06:04.160313 [ 3830 ] {188e2d88-0797-499e-9349-d197a358a7c1} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.175561 [ 3830 ] {ba20e1e3-633d-4b3f-85c5-c1dc92a33655} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianTDigestWeighted();) 2025.03.31 19:06:04.177608 [ 3830 ] {ba20e1e3-633d-4b3f-85c5-c1dc92a33655} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.286827 [ 3830 ] {d18a864d-5f65-4234-9a21-2ed89925ee80} executeQuery: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianTiming();) 2025.03.31 19:06:04.288341 [ 3830 ] {d18a864d-5f65-4234-9a21-2ed89925ee80} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:04.304778 [ 3830 ] {582daced-fa8c-4342-9c83-e1dccce60aca} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT medianTimingWeighted();) 2025.03.31 19:06:04.306603 [ 3830 ] {582daced-fa8c-4342-9c83-e1dccce60aca} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.389085 [ 3830 ] {6320c50c-d257-4886-bdb9-e7a28ce85ead} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT mid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mid();) 2025.03.31 19:06:04.391267 [ 3830 ] {6320c50c-d257-4886-bdb9-e7a28ce85ead} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT mid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.404876 [ 3830 ] {fa060cc0-c699-4c72-a728-42c1a485fdaa} executeQuery: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT min();) 2025.03.31 19:06:04.406857 [ 3830 ] {fa060cc0-c699-4c72-a728-42c1a485fdaa} TCPHandler: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.420921 [ 3830 ] {a4c0c09c-c035-47d7-aefc-e412441b04a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 0, should be 2: In scope SELECT min2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT min2();) 2025.03.31 19:06:04.422624 [ 3830 ] {a4c0c09c-c035-47d7-aefc-e412441b04a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function min2 doesn't match: passed 0, should be 2: In scope SELECT min2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.437227 [ 3830 ] {2f4fa042-af6d-4c05-be37-33151d8a5313} executeQuery: Code: 42. DB::Exception: Aggregate function minMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT minMappedArrays();) 2025.03.31 19:06:04.438925 [ 3830 ] {2f4fa042-af6d-4c05-be37-33151d8a5313} TCPHandler: Code: 42. DB::Exception: Aggregate function minMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.522372 [ 3830 ] {3a8d2006-1a8c-49ee-b836-9c495b4caace} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT minSampleSizeContinous();) 2025.03.31 19:06:04.524015 [ 3830 ] {3a8d2006-1a8c-49ee-b836-9c495b4caace} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.540091 [ 3830 ] {4c7b25dd-c722-4c82-b7b3-ed44a5a40d25} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinuous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT minSampleSizeContinuous();) 2025.03.31 19:06:04.541963 [ 3830 ] {4c7b25dd-c722-4c82-b7b3-ed44a5a40d25} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 0, should be 5: In scope SELECT minSampleSizeContinuous(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.557966 [ 3830 ] {45a08798-f63a-4861-8b75-5af577c112e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 0, should be 4: In scope SELECT minSampleSizeConversion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT minSampleSizeConversion();) 2025.03.31 19:06:04.559568 [ 3830 ] {45a08798-f63a-4861-8b75-5af577c112e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 0, should be 4: In scope SELECT minSampleSizeConversion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.574904 [ 3830 ] {9b5e4e16-00c5-4b3c-a3bd-5e21fef9f4e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 0, should be 2: In scope SELECT minus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT minus();) 2025.03.31 19:06:04.576420 [ 3830 ] {9b5e4e16-00c5-4b3c-a3bd-5e21fef9f4e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minus doesn't match: passed 0, should be 2: In scope SELECT minus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.689877 [ 3830 ] {b6a4e4d5-5d77-4324-8691-93cdefa8cae8} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT mismatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mismatches();) 2025.03.31 19:06:04.691384 [ 3830 ] {b6a4e4d5-5d77-4324-8691-93cdefa8cae8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteHammingDistance doesn't match: passed 0, should be 2: In scope SELECT mismatches(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.706988 [ 3830 ] {aa60e256-e7a8-4b58-b8d0-51e38bfb10a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT mod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mod();) 2025.03.31 19:06:04.708785 [ 3830 ] {aa60e256-e7a8-4b58-b8d0-51e38bfb10a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT mod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.725230 [ 3830 ] {37ef8b37-aaaa-4b3b-a60a-c0d3c1ebacea} executeQuery: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT modulo();) 2025.03.31 19:06:04.780938 [ 3830 ] {37ef8b37-aaaa-4b3b-a60a-c0d3c1ebacea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function modulo doesn't match: passed 0, should be 2: In scope SELECT modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.794365 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:04.798089 [ 3830 ] {db9ced27-afc1-4e4e-840c-7b6ac16ee028} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 0, should be 2: In scope SELECT moduloLegacy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT moduloLegacy();) 2025.03.31 19:06:04.799572 [ 3830 ] {db9ced27-afc1-4e4e-840c-7b6ac16ee028} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloLegacy doesn't match: passed 0, should be 2: In scope SELECT moduloLegacy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.815796 [ 3830 ] {18be67d5-3b8a-44d4-b2ca-dee14a098384} executeQuery: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 0, should be 2: In scope SELECT moduloOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT moduloOrZero();) 2025.03.31 19:06:04.817286 [ 3830 ] {18be67d5-3b8a-44d4-b2ca-dee14a098384} TCPHandler: Code: 42. DB::Exception: Number of arguments for function moduloOrZero doesn't match: passed 0, should be 2: In scope SELECT moduloOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.831397 [ 3830 ] {29db004c-7d9c-48d0-bfd8-d7c0cf06731a} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 0, should be 1: In scope SELECT monthName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT monthName();) 2025.03.31 19:06:04.832807 [ 3830 ] {29db004c-7d9c-48d0-bfd8-d7c0cf06731a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 0, should be 1: In scope SELECT monthName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.849309 [ 3830 ] {2cc110e9-0b89-448a-b6e9-ce9194f7a14a} executeQuery: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 0, should be 2: In scope SELECT mortonDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mortonDecode();) 2025.03.31 19:06:04.851426 [ 3830 ] {2cc110e9-0b89-448a-b6e9-ce9194f7a14a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mortonDecode doesn't match: passed 0, should be 2: In scope SELECT mortonDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.865961 [ 3830 ] {e5c7cff2-5141-47e7-911d-b34286a1f9ca} executeQuery: Code: 35. DB::Exception: At least one UInt argument is required for function mortonEncode: In scope SELECT mortonEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT mortonEncode();) 2025.03.31 19:06:04.867456 [ 3830 ] {e5c7cff2-5141-47e7-911d-b34286a1f9ca} TCPHandler: Code: 35. DB::Exception: At least one UInt argument is required for function mortonEncode: In scope SELECT mortonEncode(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:04.944442 [ 3830 ] {d733f166-7ab4-4c53-9a89-f530752bc099} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiFuzzyMatchAllIndices();) 2025.03.31 19:06:04.946090 [ 3830 ] {d733f166-7ab4-4c53-9a89-f530752bc099} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.960754 [ 3830 ] {5fd35f17-03fe-426c-8735-eca92bddfd99} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiFuzzyMatchAny();) 2025.03.31 19:06:04.962471 [ 3830 ] {5fd35f17-03fe-426c-8735-eca92bddfd99} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:04.977581 [ 3830 ] {9b7e6841-4d1d-44b7-a3c6-e80a36170bd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiFuzzyMatchAnyIndex();) 2025.03.31 19:06:04.979245 [ 3830 ] {9b7e6841-4d1d-44b7-a3c6-e80a36170bd1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 0, should be 3: In scope SELECT multiFuzzyMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.019084 [ 3830 ] {0036f495-1b82-49c2-9840-1c8aaa3b1243} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiIf();) 2025.03.31 19:06:05.020561 [ 3830 ] {0036f495-1b82-49c2-9840-1c8aaa3b1243} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.036202 [ 3830 ] {fc179024-8404-4c3a-9ccb-9516925ce6c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 0, should be 2: In scope SELECT multiMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiMatchAllIndices();) 2025.03.31 19:06:05.038735 [ 3830 ] {fc179024-8404-4c3a-9ccb-9516925ce6c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAllIndices doesn't match: passed 0, should be 2: In scope SELECT multiMatchAllIndices(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.091638 [ 3830 ] {97ccf2f9-f6d4-4d2d-912e-7dfe63ecbef7} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 0, should be 2: In scope SELECT multiMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiMatchAny();) 2025.03.31 19:06:05.093158 [ 3830 ] {97ccf2f9-f6d4-4d2d-912e-7dfe63ecbef7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAny doesn't match: passed 0, should be 2: In scope SELECT multiMatchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.107844 [ 3830 ] {4aceefcf-8a3a-4aff-a81c-2126756d3cf9} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 0, should be 2: In scope SELECT multiMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiMatchAnyIndex();) 2025.03.31 19:06:05.109583 [ 3830 ] {4aceefcf-8a3a-4aff-a81c-2126756d3cf9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiMatchAnyIndex doesn't match: passed 0, should be 2: In scope SELECT multiMatchAnyIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.200456 [ 3830 ] {c5bf74b9-4509-49f4-9fe0-c7aa93103307} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositions(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAllPositions();) 2025.03.31 19:06:05.202196 [ 3830 ] {c5bf74b9-4509-49f4-9fe0-c7aa93103307} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositions doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositions(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.216742 [ 3830 ] {ed423cd6-9121-492d-8e58-ce93bba3417e} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitive();) 2025.03.31 19:06:05.218581 [ 3830 ] {ed423cd6-9121-492d-8e58-ce93bba3417e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.233012 [ 3830 ] {69d529cd-b133-4072-9195-53a7c9c18448} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8();) 2025.03.31 19:06:05.234685 [ 3830 ] {69d529cd-b133-4072-9195-53a7c9c18448} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.247655 [ 3830 ] {0db56f2c-48be-468a-97ae-4337b6dcaf94} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAllPositionsUTF8();) 2025.03.31 19:06:05.248936 [ 3830 ] {0db56f2c-48be-468a-97ae-4337b6dcaf94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAllPositionsUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAllPositionsUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.262630 [ 3830 ] {a9c26672-268d-46b7-9ed6-8c060f47bffe} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 0, should be 2: In scope SELECT multiSearchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAny();) 2025.03.31 19:06:05.263745 [ 3830 ] {a9c26672-268d-46b7-9ed6-8c060f47bffe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAny doesn't match: passed 0, should be 2: In scope SELECT multiSearchAny(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.276706 [ 3830 ] {295cdecf-8ef8-4364-a0d4-7a45dc9bfe88} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAnyCaseInsensitive();) 2025.03.31 19:06:05.278028 [ 3830 ] {295cdecf-8ef8-4364-a0d4-7a45dc9bfe88} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.292856 [ 3830 ] {02ee1232-9d30-406f-8bec-ec77b69eb25d} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8();) 2025.03.31 19:06:05.294508 [ 3830 ] {02ee1232-9d30-406f-8bec-ec77b69eb25d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.392940 [ 3830 ] {b1bae6b1-9250-4e8f-869e-b062384ada5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchAnyUTF8();) 2025.03.31 19:06:05.394806 [ 3830 ] {b1bae6b1-9250-4e8f-869e-b062384ada5c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchAnyUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchAnyUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.507515 [ 3830 ] {d7c624e4-5cfb-4576-9f85-d0bb1677ffe2} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstIndex();) 2025.03.31 19:06:05.509203 [ 3830 ] {d7c624e4-5cfb-4576-9f85-d0bb1677ffe2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndex doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.523687 [ 3830 ] {188c7497-12b1-44f5-b9f2-637601c350c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitive();) 2025.03.31 19:06:05.525094 [ 3830 ] {188c7497-12b1-44f5-b9f2-637601c350c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.540249 [ 3830 ] {2967d418-d967-426e-acbb-ad33975ed965} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8();) 2025.03.31 19:06:05.541842 [ 3830 ] {2967d418-d967-426e-acbb-ad33975ed965} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.556122 [ 3830 ] {3dac24ee-a60c-4a62-b7ce-031c2681f6f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstIndexUTF8();) 2025.03.31 19:06:05.557945 [ 3830 ] {3dac24ee-a60c-4a62-b7ce-031c2681f6f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.574405 [ 3830 ] {7d1589b6-5cef-4e0e-b44f-09cd105760af} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPosition(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstPosition();) 2025.03.31 19:06:05.575999 [ 3830 ] {7d1589b6-5cef-4e0e-b44f-09cd105760af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPosition doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPosition(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.646775 [ 3830 ] {9da2e574-8f01-408b-a0aa-f815ef6a32ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitive();) 2025.03.31 19:06:05.651158 [ 3830 ] {9da2e574-8f01-408b-a0aa-f815ef6a32ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.667410 [ 3830 ] {75c2e329-fd55-4011-92d7-cd32d3147621} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8();) 2025.03.31 19:06:05.669183 [ 3830 ] {75c2e329-fd55-4011-92d7-cd32d3147621} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.685070 [ 3830 ] {f7ef6a36-0f48-40b7-9a24-c88bee24c453} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiSearchFirstPositionUTF8();) 2025.03.31 19:06:05.686966 [ 3830 ] {f7ef6a36-0f48-40b7-9a24-c88bee24c453} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiSearchFirstPositionUTF8 doesn't match: passed 0, should be 2: In scope SELECT multiSearchFirstPositionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.700899 [ 3830 ] {5b798cd5-2bcc-4dc1-b8ea-44e8189188ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT multiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiply();) 2025.03.31 19:06:05.702698 [ 3830 ] {5b798cd5-2bcc-4dc1-b8ea-44e8189188ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiply doesn't match: passed 0, should be 2: In scope SELECT multiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.718102 [ 3830 ] {f748f074-6b8a-4be2-bf3f-477f8d8fa3ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiplyDecimal does not match: 2 or 3 expected: In scope SELECT multiplyDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT multiplyDecimal();) 2025.03.31 19:06:05.719602 [ 3830 ] {f748f074-6b8a-4be2-bf3f-477f8d8fa3ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiplyDecimal does not match: 2 or 3 expected: In scope SELECT multiplyDecimal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:05.839444 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:06.008642 [ 3830 ] {92eeb745-5d04-4d03-bacd-e936279ffa9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 0, should be 1: In scope SELECT negate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT negate();) 2025.03.31 19:06:06.010647 [ 3830 ] {92eeb745-5d04-4d03-bacd-e936279ffa9b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 0, should be 1: In scope SELECT negate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.112692 [ 3830 ] {ec052628-9b2d-4a0c-a73f-afee267c0d49} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT neighbor();) 2025.03.31 19:06:06.114413 [ 3830 ] {ec052628-9b2d-4a0c-a73f-afee267c0d49} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.03.31 19:06:06.129018 [ 3830 ] {83f45950-aef4-4766-a94d-51e0290c67e6} executeQuery: Code: 35. DB::Exception: Number of arguments for function nested doesn't match: passed 0, should be at least 2: In scope SELECT nested(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nested();) 2025.03.31 19:06:06.130619 [ 3830 ] {83f45950-aef4-4766-a94d-51e0290c67e6} TCPHandler: Code: 35. DB::Exception: Number of arguments for function nested doesn't match: passed 0, should be at least 2: In scope SELECT nested(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.145288 [ 3830 ] {ac2e9a29-29d4-48ed-a4aa-35590769d570} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 0, should be 1: In scope SELECT netloc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT netloc();) 2025.03.31 19:06:06.146876 [ 3830 ] {ac2e9a29-29d4-48ed-a4aa-35590769d570} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 0, should be 1: In scope SELECT netloc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.181467 [ 3830 ] {417aa642-bed8-44ad-8448-d6f2e2b31e75} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 0, should be 2: In scope SELECT ngramDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramDistance();) 2025.03.31 19:06:06.183159 [ 3830 ] {417aa642-bed8-44ad-8448-d6f2e2b31e75} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistance doesn't match: passed 0, should be 2: In scope SELECT ngramDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.198497 [ 3830 ] {b5ea8cd8-70dc-4eac-b306-0de8c8d75516} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramDistanceCaseInsensitive();) 2025.03.31 19:06:06.199960 [ 3830 ] {b5ea8cd8-70dc-4eac-b306-0de8c8d75516} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.214978 [ 3830 ] {7d1fb01a-5a68-400a-9a2f-c936acfa4f04} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramDistanceCaseInsensitiveUTF8();) 2025.03.31 19:06:06.216465 [ 3830 ] {7d1fb01a-5a68-400a-9a2f-c936acfa4f04} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.262321 [ 3830 ] {c6aed3c5-d3d9-4f36-a7da-887ee66ae60c} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramDistanceUTF8();) 2025.03.31 19:06:06.263934 [ 3830 ] {c6aed3c5-d3d9-4f36-a7da-887ee66ae60c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramDistanceUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramDistanceUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.280496 [ 3830 ] {c19abbb9-4bc0-474b-91e8-948a2a895e9d} executeQuery: Code: 35. DB::Exception: Function ngramMinHash expect at least one argument: In scope SELECT ngramMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHash();) 2025.03.31 19:06:06.282194 [ 3830 ] {c19abbb9-4bc0-474b-91e8-948a2a895e9d} TCPHandler: Code: 35. DB::Exception: Function ngramMinHash expect at least one argument: In scope SELECT ngramMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.350386 [ 3830 ] {c6abd332-61f8-406a-8d05-c90404583f7c} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArg expect at least one argument: In scope SELECT ngramMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashArg();) 2025.03.31 19:06:06.352303 [ 3830 ] {c6abd332-61f8-406a-8d05-c90404583f7c} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArg expect at least one argument: In scope SELECT ngramMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.367703 [ 3830 ] {ce1816b3-a218-4e16-a996-c2c10813c883} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashArgCaseInsensitive();) 2025.03.31 19:06:06.369393 [ 3830 ] {ce1816b3-a218-4e16-a996-c2c10813c883} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.384777 [ 3830 ] {93a37304-9cca-404e-a130-62a492c70d4b} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashArgCaseInsensitiveUTF8();) 2025.03.31 19:06:06.386383 [ 3830 ] {93a37304-9cca-404e-a130-62a492c70d4b} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.470722 [ 3830 ] {76f4a253-d60b-4004-a39a-267911084f75} executeQuery: Code: 35. DB::Exception: Function ngramMinHashArgUTF8 expect at least one argument: In scope SELECT ngramMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashArgUTF8();) 2025.03.31 19:06:06.472243 [ 3830 ] {76f4a253-d60b-4004-a39a-267911084f75} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashArgUTF8 expect at least one argument: In scope SELECT ngramMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.489019 [ 3830 ] {09d920ef-8fbc-4d27-a2d3-916dd5dca01a} executeQuery: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashCaseInsensitive();) 2025.03.31 19:06:06.492750 [ 3830 ] {09d920ef-8fbc-4d27-a2d3-916dd5dca01a} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitive expect at least one argument: In scope SELECT ngramMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.508943 [ 3830 ] {74daa917-d508-4cc2-bc50-f38103e1b760} executeQuery: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashCaseInsensitiveUTF8();) 2025.03.31 19:06:06.510622 [ 3830 ] {74daa917-d508-4cc2-bc50-f38103e1b760} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.525414 [ 3830 ] {d88a0f65-c0f6-4889-97b3-c446a08eb8b9} executeQuery: Code: 35. DB::Exception: Function ngramMinHashUTF8 expect at least one argument: In scope SELECT ngramMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramMinHashUTF8();) 2025.03.31 19:06:06.527021 [ 3830 ] {d88a0f65-c0f6-4889-97b3-c446a08eb8b9} TCPHandler: Code: 35. DB::Exception: Function ngramMinHashUTF8 expect at least one argument: In scope SELECT ngramMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.540484 [ 3830 ] {9ad684ad-ac58-4b45-b9b4-04a095838f41} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 0, should be 2: In scope SELECT ngramSearch(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSearch();) 2025.03.31 19:06:06.542037 [ 3830 ] {9ad684ad-ac58-4b45-b9b4-04a095838f41} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearch doesn't match: passed 0, should be 2: In scope SELECT ngramSearch(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.557643 [ 3830 ] {19f9f9b8-a487-4bc3-ac98-862cdd811490} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSearchCaseInsensitive();) 2025.03.31 19:06:06.559392 [ 3830 ] {19f9f9b8-a487-4bc3-ac98-862cdd811490} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitive doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.574628 [ 3830 ] {f2cc21b7-f54a-424e-9d38-d730358b12e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSearchCaseInsensitiveUTF8();) 2025.03.31 19:06:06.576329 [ 3830 ] {f2cc21b7-f54a-424e-9d38-d730358b12e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchCaseInsensitiveUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.591421 [ 3830 ] {33917853-cc3b-4957-98cf-e078fca53be1} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSearchUTF8();) 2025.03.31 19:06:06.592898 [ 3830 ] {33917853-cc3b-4957-98cf-e078fca53be1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngramSearchUTF8 doesn't match: passed 0, should be 2: In scope SELECT ngramSearchUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.675302 [ 3830 ] {92501481-7b4c-47b0-b401-59e16f3e73f8} executeQuery: Code: 35. DB::Exception: Function ngramSimHash expect at least one argument: In scope SELECT ngramSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSimHash();) 2025.03.31 19:06:06.676791 [ 3830 ] {92501481-7b4c-47b0-b401-59e16f3e73f8} TCPHandler: Code: 35. DB::Exception: Function ngramSimHash expect at least one argument: In scope SELECT ngramSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.691165 [ 3830 ] {deafb126-6657-4783-af08-be897e1d6964} executeQuery: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitive expect at least one argument: In scope SELECT ngramSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSimHashCaseInsensitive();) 2025.03.31 19:06:06.692602 [ 3830 ] {deafb126-6657-4783-af08-be897e1d6964} TCPHandler: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitive expect at least one argument: In scope SELECT ngramSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.707088 [ 3830 ] {b39347d7-b7c5-4e31-8608-e32b9086a7bf} executeQuery: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSimHashCaseInsensitiveUTF8();) 2025.03.31 19:06:06.708501 [ 3830 ] {b39347d7-b7c5-4e31-8608-e32b9086a7bf} TCPHandler: Code: 35. DB::Exception: Function ngramSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT ngramSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.724097 [ 3830 ] {5b1f9336-3583-4456-9858-27236a30b1ba} executeQuery: Code: 35. DB::Exception: Function ngramSimHashUTF8 expect at least one argument: In scope SELECT ngramSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngramSimHashUTF8();) 2025.03.31 19:06:06.725680 [ 3830 ] {5b1f9336-3583-4456-9858-27236a30b1ba} TCPHandler: Code: 35. DB::Exception: Function ngramSimHashUTF8 expect at least one argument: In scope SELECT ngramSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:06.741674 [ 3830 ] {abfe9baa-9b45-4546-a17f-f0a600bc7ddf} executeQuery: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 0, should be 2: In scope SELECT ngrams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ngrams();) 2025.03.31 19:06:06.743415 [ 3830 ] {abfe9baa-9b45-4546-a17f-f0a600bc7ddf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ngrams doesn't match: passed 0, should be 2: In scope SELECT ngrams(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.760891 [ 3830 ] {53440afc-b2cf-4be6-a87c-ecae60d8401b} executeQuery: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nonNegativeDerivative();) 2025.03.31 19:06:06.762616 [ 3830 ] {53440afc-b2cf-4be6-a87c-ecae60d8401b} TCPHandler: Code: 42. DB::Exception: Function nonNegativeDerivative takes 2 or 3 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.777491 [ 3830 ] {10268908-ccc5-41eb-83a2-280ea42e7065} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT normL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normL1();) 2025.03.31 19:06:06.779067 [ 3830 ] {10268908-ccc5-41eb-83a2-280ea42e7065} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 0, should be 1: In scope SELECT normL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.792452 [ 3830 ] {dc65c240-a28f-4432-8520-c7dcf6276f8c} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT normL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normL2();) 2025.03.31 19:06:06.794030 [ 3830 ] {dc65c240-a28f-4432-8520-c7dcf6276f8c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 0, should be 1: In scope SELECT normL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.809356 [ 3830 ] {01a3f3f1-3839-402a-92ae-4d7ccd533a13} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT normL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normL2Squared();) 2025.03.31 19:06:06.811011 [ 3830 ] {01a3f3f1-3839-402a-92ae-4d7ccd533a13} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 0, should be 1: In scope SELECT normL2Squared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.826549 [ 3830 ] {56d6e877-6617-450a-a8f1-a5110a0c49df} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT normLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normLinf();) 2025.03.31 19:06:06.828245 [ 3830 ] {56d6e877-6617-450a-a8f1-a5110a0c49df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 0, should be 1: In scope SELECT normLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.843607 [ 3830 ] {126d1ca5-0060-4f63-8c0d-12624689e88b} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT normLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normLp();) 2025.03.31 19:06:06.845081 [ 3830 ] {126d1ca5-0060-4f63-8c0d-12624689e88b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNorm doesn't match: passed 0, should be 2: In scope SELECT normLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.914470 [ 3830 ] {1d1a9e9e-8110-459e-b5d2-2c481af71da9} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeL1();) 2025.03.31 19:06:06.915895 [ 3830 ] {1d1a9e9e-8110-459e-b5d2-2c481af71da9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL1(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.930445 [ 3830 ] {dd19e266-ccfb-4a78-934e-2cef26bdcf6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeL2();) 2025.03.31 19:06:06.931956 [ 3830 ] {dd19e266-ccfb-4a78-934e-2cef26bdcf6a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 0, should be 1: In scope SELECT normalizeL2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:06.956740 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:06.982975 [ 3830 ] {28053932-e92e-42ad-9989-28f04262bc38} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT normalizeLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeLinf();) 2025.03.31 19:06:06.984734 [ 3830 ] {28053932-e92e-42ad-9989-28f04262bc38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 0, should be 1: In scope SELECT normalizeLinf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.000386 [ 3830 ] {92bf8c5b-66c8-4477-97fb-b2ed9021a5ad} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT normalizeLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeLp();) 2025.03.31 19:06:07.002327 [ 3830 ] {92bf8c5b-66c8-4477-97fb-b2ed9021a5ad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpNormalize doesn't match: passed 0, should be 2: In scope SELECT normalizeLp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.090751 [ 3830 ] {82474472-e92d-478b-b057-1706313f4498} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 0, should be 1: In scope SELECT normalizeQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeQuery();) 2025.03.31 19:06:07.092891 [ 3830 ] {82474472-e92d-478b-b057-1706313f4498} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 0, should be 1: In scope SELECT normalizeQuery(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.109311 [ 3830 ] {b033949d-f39c-447b-9c67-6d984e98127d} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizeQueryKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeQueryKeepNames();) 2025.03.31 19:06:07.110931 [ 3830 ] {b033949d-f39c-447b-9c67-6d984e98127d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizeQueryKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.127197 [ 3830 ] {f7fd06f6-0bb6-4c34-bad5-eaf2188c8288} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeUTF8NFC();) 2025.03.31 19:06:07.128642 [ 3830 ] {f7fd06f6-0bb6-4c34-bad5-eaf2188c8288} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.211720 [ 3830 ] {bb7bfdeb-9b5b-4c09-837e-70b93556b981} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeUTF8NFD();) 2025.03.31 19:06:07.213389 [ 3830 ] {bb7bfdeb-9b5b-4c09-837e-70b93556b981} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.230515 [ 3830 ] {dbe8854a-a4ad-4a49-aa08-f11f1da32206} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeUTF8NFKC();) 2025.03.31 19:06:07.232225 [ 3830 ] {dbe8854a-a4ad-4a49-aa08-f11f1da32206} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.247929 [ 3830 ] {3916e219-5d8f-4d37-860e-d0057e5df528} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizeUTF8NFKD();) 2025.03.31 19:06:07.249375 [ 3830 ] {3916e219-5d8f-4d37-860e-d0057e5df528} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 0, should be 1: In scope SELECT normalizeUTF8NFKD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.266034 [ 3830 ] {eb2b6631-5b73-433a-9b4a-bd9a614dcb40} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizedQueryHash();) 2025.03.31 19:06:07.267751 [ 3830 ] {eb2b6631-5b73-433a-9b4a-bd9a614dcb40} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.351698 [ 3830 ] {511c375c-b76b-4966-8607-202683e031c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHashKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT normalizedQueryHashKeepNames();) 2025.03.31 19:06:07.353382 [ 3830 ] {511c375c-b76b-4966-8607-202683e031c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 0, should be 1: In scope SELECT normalizedQueryHashKeepNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.368108 [ 3830 ] {980c9175-1fa2-4452-8d6b-1834f2171717} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 0, should be 1: In scope SELECT not(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT not();) 2025.03.31 19:06:07.369573 [ 3830 ] {980c9175-1fa2-4452-8d6b-1834f2171717} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 0, should be 1: In scope SELECT not(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.385682 [ 3830 ] {c867c12f-d365-4704-9422-97b9e0d973b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 0, should be 1: In scope SELECT notEmpty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notEmpty();) 2025.03.31 19:06:07.387269 [ 3830 ] {c867c12f-d365-4704-9422-97b9e0d973b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 0, should be 1: In scope SELECT notEmpty(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.402543 [ 3830 ] {ac86004b-7d13-437f-9194-f58b68cb240a} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 0, should be 2: In scope SELECT notEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notEquals();) 2025.03.31 19:06:07.404248 [ 3830 ] {ac86004b-7d13-437f-9194-f58b68cb240a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEquals doesn't match: passed 0, should be 2: In scope SELECT notEquals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.418537 [ 3830 ] {672bc383-6681-4d65-9b58-ff157f1f8722} executeQuery: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 0, should be 2: In scope SELECT notILike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notILike();) 2025.03.31 19:06:07.419889 [ 3830 ] {672bc383-6681-4d65-9b58-ff157f1f8722} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notILike doesn't match: passed 0, should be 2: In scope SELECT notILike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.436114 [ 3830 ] {91d904c7-de39-4170-b86c-24182fc7004d} executeQuery: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notIn();) 2025.03.31 19:06:07.437635 [ 3830 ] {91d904c7-de39-4170-b86c-24182fc7004d} TCPHandler: Code: 42. DB::Exception: Function 'notIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.502252 [ 3830 ] {6bb08744-fcbe-4037-ac11-e443c4ef477c} executeQuery: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notInIgnoreSet();) 2025.03.31 19:06:07.504017 [ 3830 ] {6bb08744-fcbe-4037-ac11-e443c4ef477c} TCPHandler: Code: 42. DB::Exception: Function 'notInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.565566 [ 3830 ] {7803f779-2308-44c7-b0b7-06971028e148} executeQuery: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 0, should be 2: In scope SELECT notLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notLike();) 2025.03.31 19:06:07.567335 [ 3830 ] {7803f779-2308-44c7-b0b7-06971028e148} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notLike doesn't match: passed 0, should be 2: In scope SELECT notLike(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.582906 [ 3830 ] {7724762d-f0d4-4515-b0dc-b5498394b096} executeQuery: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notNullIn();) 2025.03.31 19:06:07.584388 [ 3830 ] {7724762d-f0d4-4515-b0dc-b5498394b096} TCPHandler: Code: 42. DB::Exception: Function 'notNullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:07.674960 [ 3830 ] {26a9be6e-b11a-4eb2-b776-4198898537b4} executeQuery: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT notNullInIgnoreSet();) 2025.03.31 19:06:07.676918 [ 3830 ] {26a9be6e-b11a-4eb2-b776-4198898537b4} TCPHandler: Code: 42. DB::Exception: Function 'notNullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.020143 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:08.238169 [ 3830 ] {09829396-1957-4b8b-b854-f4c8d6f713f3} executeQuery: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nth_value();) 2025.03.31 19:06:08.239708 [ 3830 ] {09829396-1957-4b8b-b854-f4c8d6f713f3} TCPHandler: Code: 42. DB::Exception: Function nth_value takes exactly two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.254254 [ 3830 ] {57577f6f-d7f7-49f6-acec-9dfb6dd383e6} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ntile();) 2025.03.31 19:06:08.255797 [ 3830 ] {57577f6f-d7f7-49f6-acec-9dfb6dd383e6} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.270486 [ 3830 ] {5f2deef9-a0f2-4d7c-85a6-7daa2a13618d} executeQuery: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 0, should be 2: In scope SELECT nullIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nullIf();) 2025.03.31 19:06:08.272177 [ 3830 ] {5f2deef9-a0f2-4d7c-85a6-7daa2a13618d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function nullIf doesn't match: passed 0, should be 2: In scope SELECT nullIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.287326 [ 3830 ] {ded4364a-a9a7-4fb7-b794-b351fc34360d} executeQuery: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nullIn();) 2025.03.31 19:06:08.288932 [ 3830 ] {ded4364a-a9a7-4fb7-b794-b351fc34360d} TCPHandler: Code: 42. DB::Exception: Function 'nullIn' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.302446 [ 3830 ] {4a9b73af-93cc-44e4-bea5-212975449451} executeQuery: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT nullInIgnoreSet();) 2025.03.31 19:06:08.303869 [ 3830 ] {4a9b73af-93cc-44e4-bea5-212975449451} TCPHandler: Code: 42. DB::Exception: Function 'nullInIgnoreSet' expects 2 arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.318362 [ 3830 ] {ee38e51b-864d-4384-ab23-1b94f6075902} executeQuery: Code: 35. DB::Exception: Number of arguments for function "or" should be at least 2: passed 0: In scope SELECT or(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT or();) 2025.03.31 19:06:08.319862 [ 3830 ] {ee38e51b-864d-4384-ab23-1b94f6075902} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "or" should be at least 2: passed 0: In scope SELECT or(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:08.335038 [ 3830 ] {f9072a61-4dd4-4f8f-a0ac-f96c56f701fc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime();) 2025.03.31 19:06:08.336593 [ 3830 ] {f9072a61-4dd4-4f8f-a0ac-f96c56f701fc} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.351025 [ 3830 ] {9e6e7b56-6efd-428f-bc3e-03aecaafb29a} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime32BestEffort();) 2025.03.31 19:06:08.356911 [ 3830 ] {9e6e7b56-6efd-428f-bc3e-03aecaafb29a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.371199 [ 3830 ] {c5063227-de33-4d28-a63d-154c07424585} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime32BestEffortOrNull();) 2025.03.31 19:06:08.372670 [ 3830 ] {c5063227-de33-4d28-a63d-154c07424585} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.387129 [ 3830 ] {393a8abd-c1c2-4b50-b6da-2f08bb396221} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime32BestEffortOrZero();) 2025.03.31 19:06:08.388539 [ 3830 ] {393a8abd-c1c2-4b50-b6da-2f08bb396221} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTime32BestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTime32BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.403374 [ 3830 ] {96bc2fbc-cfdb-4da2-bb25-efc16069866a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffort'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffort();) 2025.03.31 19:06:08.405351 [ 3830 ] {96bc2fbc-cfdb-4da2-bb25-efc16069866a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffort'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.421209 [ 3830 ] {1b429462-52d3-4575-81f9-def9ed97dfeb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffortOrNull();) 2025.03.31 19:06:08.422871 [ 3830 ] {1b429462-52d3-4575-81f9-def9ed97dfeb} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.438748 [ 3830 ] {c8461fd8-2cef-475c-a75c-394c392a3969} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffortOrZero();) 2025.03.31 19:06:08.440193 [ 3830 ] {c8461fd8-2cef-475c-a75c-394c392a3969} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.474069 [ 3830 ] {1d0f9251-718a-48eb-b65a-0ebdfae09723} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUS'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffortUS();) 2025.03.31 19:06:08.475954 [ 3830 ] {1d0f9251-718a-48eb-b65a-0ebdfae09723} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUS'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.490221 [ 3830 ] {2864258d-abaa-4f56-b3a5-1138060323bf} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffortUSOrNull();) 2025.03.31 19:06:08.492021 [ 3830 ] {2864258d-abaa-4f56-b3a5-1138060323bf} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.507928 [ 3830 ] {e6f34a5e-e256-4d45-a3a3-c5cc0660bf99} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTime64BestEffortUSOrZero();) 2025.03.31 19:06:08.509584 [ 3830 ] {e6f34a5e-e256-4d45-a3a3-c5cc0660bf99} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTime64BestEffortUSOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTime64BestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.621209 [ 3830 ] {61fe4a43-17cf-4dbb-bbbf-1b846ee61c60} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffort();) 2025.03.31 19:06:08.622956 [ 3830 ] {61fe4a43-17cf-4dbb-bbbf-1b846ee61c60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffort doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffort(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.640109 [ 3830 ] {9ffc92b0-b662-4461-b940-98432e2e4379} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffortOrNull();) 2025.03.31 19:06:08.642096 [ 3830 ] {9ffc92b0-b662-4461-b940-98432e2e4379} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.657338 [ 3830 ] {7dbdab36-28c2-4d29-a671-a35af8c858c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffortOrZero();) 2025.03.31 19:06:08.659294 [ 3830 ] {7dbdab36-28c2-4d29-a671-a35af8c858c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.673511 [ 3830 ] {444dac2a-f714-435a-b8b9-d6f846abd028} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffortUS();) 2025.03.31 19:06:08.676893 [ 3830 ] {444dac2a-f714-435a-b8b9-d6f846abd028} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUS doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUS(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.690135 [ 3830 ] {3ef07c69-f3ce-4052-9be9-31bb26343b52} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffortUSOrNull();) 2025.03.31 19:06:08.691491 [ 3830 ] {3ef07c69-f3ce-4052-9be9-31bb26343b52} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.703683 [ 3830 ] {39e81b23-0572-4143-87db-874bbf274f43} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeBestEffortUSOrZero();) 2025.03.31 19:06:08.704809 [ 3830 ] {39e81b23-0572-4143-87db-874bbf274f43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseDateTimeBestEffortUSOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT parseDateTimeBestEffortUSOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.719771 [ 3830 ] {b2d3c762-749e-4eb2-b970-a524aaeaa596} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntax'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeInJodaSyntax();) 2025.03.31 19:06:08.721582 [ 3830 ] {b2d3c762-749e-4eb2-b970-a524aaeaa596} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntax'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntax(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.832910 [ 3830 ] {9d1a4b38-1949-45ba-a4b3-74e24353f735} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeInJodaSyntaxOrNull();) 2025.03.31 19:06:08.836061 [ 3830 ] {9d1a4b38-1949-45ba-a4b3-74e24353f735} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.849930 [ 3830 ] {3cc81d36-2beb-4f03-bf0d-746f691447f6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeInJodaSyntaxOrZero();) 2025.03.31 19:06:08.851498 [ 3830 ] {3cc81d36-2beb-4f03-bf0d-746f691447f6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeInJodaSyntaxOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeInJodaSyntaxOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.866112 [ 3830 ] {dc82491e-51b9-4c5f-99a7-9955636f1d9f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeOrNull();) 2025.03.31 19:06:08.867649 [ 3830 ] {dc82491e-51b9-4c5f-99a7-9955636f1d9f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.955615 [ 3830 ] {04f6a4bc-5a61-418d-b7ee-806d80832ff8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseDateTimeOrZero();) 2025.03.31 19:06:08.957685 [ 3830 ] {04f6a4bc-5a61-418d-b7ee-806d80832ff8} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT parseDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:08.972964 [ 3830 ] {5d8a8276-ef31-42d9-bf0d-5636eddf9e66} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 0, should be 1: In scope SELECT parseReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseReadableSize();) 2025.03.31 19:06:09.047314 [ 3830 ] {5d8a8276-ef31-42d9-bf0d-5636eddf9e66} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 0, should be 1: In scope SELECT parseReadableSize(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.062472 [ 3830 ] {f477c528-87c2-4962-a95c-548e34ade8eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseReadableSizeOrNull();) 2025.03.31 19:06:09.063881 [ 3830 ] {f477c528-87c2-4962-a95c-548e34ade8eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.077077 [ 3830 ] {f59ec723-fc10-4a40-ab2e-f6de1ce69f2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseReadableSizeOrZero();) 2025.03.31 19:06:09.078649 [ 3830 ] {f59ec723-fc10-4a40-ab2e-f6de1ce69f2b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 0, should be 1: In scope SELECT parseReadableSizeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.092228 [ 3830 ] {cb8d818c-c8a0-4615-baf9-b7a54b0fd61b} executeQuery: Code: 35. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 0, should be 1.: In scope SELECT parseTimeDelta(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT parseTimeDelta();) 2025.03.31 19:06:09.093608 [ 3830 ] {cb8d818c-c8a0-4615-baf9-b7a54b0fd61b} TCPHandler: Code: 35. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 0, should be 1.: In scope SELECT parseTimeDelta(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:09.106202 [ 3830 ] {c7842457-6aac-4db3-b2d5-5d91d5cb769a} executeQuery: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT partitionID();) 2025.03.31 19:06:09.107602 [ 3830 ] {c7842457-6aac-4db3-b2d5-5d91d5cb769a} TCPHandler: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.121681 [ 3830 ] {938dabf9-dd64-473f-a159-a716d0236329} executeQuery: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionId(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT partitionId();) 2025.03.31 19:06:09.123204 [ 3830 ] {938dabf9-dd64-473f-a159-a716d0236329} TCPHandler: Code: 42. DB::Exception: Function partitionId requires at least one argument.: In scope SELECT partitionId(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.136979 [ 3830 ] {b3bda630-13f3-451d-9a31-c53a7b339fc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 0, should be 1: In scope SELECT path(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT path();) 2025.03.31 19:06:09.138159 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:09.138570 [ 3830 ] {b3bda630-13f3-451d-9a31-c53a7b339fc8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 0, should be 1: In scope SELECT path(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.154215 [ 3830 ] {3fdaa303-43cf-43b7-b4f4-5d5c535f9202} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 0, should be 1: In scope SELECT pathFull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT pathFull();) 2025.03.31 19:06:09.155807 [ 3830 ] {3fdaa303-43cf-43b7-b4f4-5d5c535f9202} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 0, should be 1: In scope SELECT pathFull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.179749 [ 3830 ] {5d411e8f-73af-4709-a826-852b7b1419c0} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT percentRank();) 2025.03.31 19:06:09.181840 [ 3830 ] {5d411e8f-73af-4709-a826-852b7b1419c0} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.03.31 19:06:09.209289 [ 3830 ] {b7a01dc2-6cbb-494a-b3e9-e72e7c4e1b23} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT percent_rank();) 2025.03.31 19:06:09.211681 [ 3830 ] {b7a01dc2-6cbb-494a-b3e9-e72e7c4e1b23} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.03.31 19:06:09.334845 [ 3830 ] {48007639-01aa-4ad7-8c5a-8ec54b252df5} executeQuery: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT plus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT plus();) 2025.03.31 19:06:09.336589 [ 3830 ] {48007639-01aa-4ad7-8c5a-8ec54b252df5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function plus doesn't match: passed 0, should be 2: In scope SELECT plus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.351342 [ 3830 ] {374a21ea-cdb8-46e6-9c18-03b64141142b} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT pmod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT pmod();) 2025.03.31 19:06:09.352836 [ 3830 ] {374a21ea-cdb8-46e6-9c18-03b64141142b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT pmod(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.367275 [ 3830 ] {e15e650d-af16-4fed-847a-70efcddfb891} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT pointInEllipses();) 2025.03.31 19:06:09.368737 [ 3830 ] {e15e650d-af16-4fed-847a-70efcddfb891} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.382995 [ 3830 ] {c8d11432-c734-411e-823b-0dab1458f1bc} executeQuery: Code: 35. DB::Exception: Function pointInPolygon requires at least 2 arguments: In scope SELECT pointInPolygon(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT pointInPolygon();) 2025.03.31 19:06:09.384623 [ 3830 ] {c8d11432-c734-411e-823b-0dab1458f1bc} TCPHandler: Code: 35. DB::Exception: Function pointInPolygon requires at least 2 arguments: In scope SELECT pointInPolygon(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:09.398423 [ 3830 ] {3fc31e00-47bb-4136-ae33-0d6454479273} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonAreaCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonAreaCartesian();) 2025.03.31 19:06:09.399895 [ 3830 ] {3fc31e00-47bb-4136-ae33-0d6454479273} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonAreaCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.414219 [ 3830 ] {ddc582f2-d10d-42a3-9a74-5f22f30ea11e} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonAreaSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonAreaSpherical();) 2025.03.31 19:06:09.415742 [ 3830 ] {ddc582f2-d10d-42a3-9a74-5f22f30ea11e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonAreaSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.476949 [ 3830 ] {8e8520f5-917b-4f3c-8c33-a7a6b0ce1dea} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonConvexHullCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonConvexHullCartesian();) 2025.03.31 19:06:09.478941 [ 3830 ] {8e8520f5-917b-4f3c-8c33-a7a6b0ce1dea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonConvexHullCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.493175 [ 3830 ] {cd4f93c3-b900-441c-ab77-0ced5bfa51e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonPerimeterCartesian();) 2025.03.31 19:06:09.495082 [ 3830 ] {cd4f93c3-b900-441c-ab77-0ced5bfa51e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.510151 [ 3830 ] {e7572f65-6d27-496a-98ea-514080b5d3ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonPerimeterSpherical();) 2025.03.31 19:06:09.511873 [ 3830 ] {e7572f65-6d27-496a-98ea-514080b5d3ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 0, should be 1: In scope SELECT polygonPerimeterSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.526338 [ 3830 ] {b2f43503-13ae-46d9-8d71-7d8550538d1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsDistanceCartesian();) 2025.03.31 19:06:09.527835 [ 3830 ] {b2f43503-13ae-46d9-8d71-7d8550538d1c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.542733 [ 3830 ] {8e5769e4-28da-4075-8723-e1c9a1ab0cd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsDistanceSpherical();) 2025.03.31 19:06:09.544248 [ 3830 ] {8e5769e4-28da-4075-8723-e1c9a1ab0cd2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsDistanceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsDistanceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.559027 [ 3830 ] {82766241-bb99-4316-8b18-46b3fca4a590} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsEqualsCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsEqualsCartesian();) 2025.03.31 19:06:09.560768 [ 3830 ] {82766241-bb99-4316-8b18-46b3fca4a590} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsEqualsCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsEqualsCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.616214 [ 3830 ] {78e4bb7e-bad7-4ca8-86c7-445d538ac5f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsIntersectionCartesian();) 2025.03.31 19:06:09.617978 [ 3830 ] {78e4bb7e-bad7-4ca8-86c7-445d538ac5f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.631189 [ 3830 ] {d40df0fc-9acf-4044-b233-136507446d90} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsIntersectionSpherical();) 2025.03.31 19:06:09.632556 [ 3830 ] {d40df0fc-9acf-4044-b233-136507446d90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsIntersectionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsIntersectionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.644947 [ 3830 ] {ee990611-ae35-444a-9395-ad0ec9f6a17b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsSymDifferenceCartesian();) 2025.03.31 19:06:09.646346 [ 3830 ] {ee990611-ae35-444a-9395-ad0ec9f6a17b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.658555 [ 3830 ] {a23264f9-4990-48c1-9a07-08942b0b9b60} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsSymDifferenceSpherical();) 2025.03.31 19:06:09.659753 [ 3830 ] {a23264f9-4990-48c1-9a07-08942b0b9b60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsSymDifferenceSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsSymDifferenceSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.674790 [ 3830 ] {b7d2317d-5c68-4087-bdb9-51307876b00f} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsUnionCartesian();) 2025.03.31 19:06:09.676453 [ 3830 ] {b7d2317d-5c68-4087-bdb9-51307876b00f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.690814 [ 3830 ] {3c0886b3-1020-4103-8678-ad2cf67e0635} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsUnionSpherical();) 2025.03.31 19:06:09.692448 [ 3830 ] {3c0886b3-1020-4103-8678-ad2cf67e0635} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsUnionSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsUnionSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.707132 [ 3830 ] {ecc3fe84-7f5b-4cb2-9726-1e938c83cb74} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsWithinCartesian();) 2025.03.31 19:06:09.708500 [ 3830 ] {ecc3fe84-7f5b-4cb2-9726-1e938c83cb74} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinCartesian doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinCartesian(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.723322 [ 3830 ] {d6014ff7-58d3-4a5e-bc40-b46d3bec2eb7} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT polygonsWithinSpherical();) 2025.03.31 19:06:09.724882 [ 3830 ] {d6014ff7-58d3-4a5e-bc40-b46d3bec2eb7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonsWithinSpherical doesn't match: passed 0, should be 2: In scope SELECT polygonsWithinSpherical(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.737300 [ 3830 ] {7a794a60-3173-41fe-b40d-a80840446d7a} executeQuery: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 0, should be 1 or 2: In scope SELECT port(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT port();) 2025.03.31 19:06:09.738732 [ 3830 ] {7a794a60-3173-41fe-b40d-a80840446d7a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function port doesn't match: passed 0, should be 1 or 2: In scope SELECT port(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.813022 [ 3830 ] {b171c2eb-658c-47fa-910a-fc8bea68410e} executeQuery: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 0, should be 1 or 2: In scope SELECT portRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT portRFC();) 2025.03.31 19:06:09.814624 [ 3830 ] {b171c2eb-658c-47fa-910a-fc8bea68410e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function portRFC doesn't match: passed 0, should be 1 or 2: In scope SELECT portRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.830789 [ 3830 ] {2864b635-29b8-42b4-b762-c9ecd6086ff8} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT positionCaseInsensitive();) 2025.03.31 19:06:09.832182 [ 3830 ] {2864b635-29b8-42b4-b762-c9ecd6086ff8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitive doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitive(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.846371 [ 3830 ] {2ec4e9f5-0bd6-40c0-8b16-4b8c252eb154} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT positionCaseInsensitiveUTF8();) 2025.03.31 19:06:09.847846 [ 3830 ] {2ec4e9f5-0bd6-40c0-8b16-4b8c252eb154} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionCaseInsensitiveUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionCaseInsensitiveUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.863543 [ 3830 ] {31613ea5-3a89-4186-8c2d-84bbb946847e} executeQuery: Code: 42. DB::Exception: Number of arguments for function positionUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT positionUTF8();) 2025.03.31 19:06:09.865269 [ 3830 ] {31613ea5-3a89-4186-8c2d-84bbb946847e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positionUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT positionUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.881627 [ 3830 ] {eb649f38-6bfd-408b-856f-8533b463dea8} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positiveModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT positiveModulo();) 2025.03.31 19:06:09.883287 [ 3830 ] {eb649f38-6bfd-408b-856f-8533b463dea8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positiveModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.896836 [ 3830 ] {d3b6615b-30da-404d-98d2-8a5eedbbcfa9} executeQuery: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positive_modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT positive_modulo();) 2025.03.31 19:06:09.898286 [ 3830 ] {d3b6615b-30da-404d-98d2-8a5eedbbcfa9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function positiveModulo doesn't match: passed 0, should be 2: In scope SELECT positive_modulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.911020 [ 3830 ] {0260b08f-4802-4945-ad11-fdc639e359cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT pow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT pow();) 2025.03.31 19:06:09.912480 [ 3830 ] {0260b08f-4802-4945-ad11-fdc639e359cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT pow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.927038 [ 3830 ] {503e2cb9-e685-4389-a035-8e82e934d535} executeQuery: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT power(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT power();) 2025.03.31 19:06:09.928585 [ 3830 ] {503e2cb9-e685-4389-a035-8e82e934d535} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pow doesn't match: passed 0, should be 2: In scope SELECT power(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.942576 [ 3830 ] {f3ad6ad3-bc48-4f8b-8c35-b629dece9456} executeQuery: Code: 42. DB::Exception: Number of arguments for function printf doesn't match: passed 0, should be at least 1: In scope SELECT printf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT printf();) 2025.03.31 19:06:09.944131 [ 3830 ] {f3ad6ad3-bc48-4f8b-8c35-b629dece9456} TCPHandler: Code: 42. DB::Exception: Number of arguments for function printf doesn't match: passed 0, should be at least 1: In scope SELECT printf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:09.990632 [ 3830 ] {424e6cab-05fc-46c8-95f9-a617441a4876} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 0, should be 6: In scope SELECT proportionsZTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT proportionsZTest();) 2025.03.31 19:06:09.992036 [ 3830 ] {424e6cab-05fc-46c8-95f9-a617441a4876} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 0, should be 6: In scope SELECT proportionsZTest(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.004943 [ 3830 ] {3977a526-9bd0-4660-8bf4-7b3724bc34d0} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 0, should be 1: In scope SELECT protocol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT protocol();) 2025.03.31 19:06:10.006512 [ 3830 ] {3977a526-9bd0-4660-8bf4-7b3724bc34d0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 0, should be 1: In scope SELECT protocol(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.020964 [ 3830 ] {7872668b-18f3-4f24-b21d-afce7106c5fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 0, should be 1: In scope SELECT punycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT punycodeDecode();) 2025.03.31 19:06:10.022507 [ 3830 ] {7872668b-18f3-4f24-b21d-afce7106c5fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 0, should be 1: In scope SELECT punycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.037688 [ 3830 ] {6754a19d-76bc-4235-a1a0-9e147d656419} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 0, should be 1: In scope SELECT punycodeEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT punycodeEncode();) 2025.03.31 19:06:10.039541 [ 3830 ] {6754a19d-76bc-4235-a1a0-9e147d656419} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 0, should be 1: In scope SELECT punycodeEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.052222 [ 3830 ] {fd3b147e-e1b7-4579-be27-79c6d7432c5d} executeQuery: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantile();) 2025.03.31 19:06:10.053582 [ 3830 ] {fd3b147e-e1b7-4579-be27-79c6d7432c5d} TCPHandler: Code: 35. DB::Exception: Aggregate function quantile requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:10.066732 [ 3830 ] {ff716095-ad91-4151-b7b5-f19eb1e9a94d} executeQuery: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileBFloat16();) 2025.03.31 19:06:10.068212 [ 3830 ] {ff716095-ad91-4151-b7b5-f19eb1e9a94d} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.082045 [ 3830 ] {73507e8b-b03b-452a-8702-724443fe1441} executeQuery: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileBFloat16Weighted();) 2025.03.31 19:06:10.083625 [ 3830 ] {73507e8b-b03b-452a-8702-724443fe1441} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:10.194269 [ 3830 ] {59710929-51a2-4232-a2bf-8ce17043328d} executeQuery: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileDD();) 2025.03.31 19:06:10.195812 [ 3830 ] {59710929-51a2-4232-a2bf-8ce17043328d} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:10.209820 [ 3830 ] {73038d26-ea01-4d38-8103-a123175475fc} executeQuery: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileDeterministic();) 2025.03.31 19:06:10.211326 [ 3830 ] {73038d26-ea01-4d38-8103-a123175475fc} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.224769 [ 3830 ] {de7e88ff-abeb-46d0-b122-94ea5fcac7d6} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExact();) 2025.03.31 19:06:10.226346 [ 3830 ] {de7e88ff-abeb-46d0-b122-94ea5fcac7d6} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.235394 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:10.241058 [ 3830 ] {9a464be7-99ad-4e49-8f9c-fbb5748ca94c} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExactExclusive();) 2025.03.31 19:06:10.242807 [ 3830 ] {9a464be7-99ad-4e49-8f9c-fbb5748ca94c} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.259386 [ 3830 ] {40dcb984-09b1-4c7b-bb0c-a27049814347} executeQuery: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExactHigh();) 2025.03.31 19:06:10.261298 [ 3830 ] {40dcb984-09b1-4c7b-bb0c-a27049814347} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:10.277069 [ 3830 ] {724f1094-9565-4da5-b824-c67a97217288} executeQuery: Code: 35. DB::Exception: Aggregate function quantileExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExactInclusive();) 2025.03.31 19:06:10.377060 [ 3830 ] {724f1094-9565-4da5-b824-c67a97217288} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:10.392462 [ 3830 ] {65acfeee-7e9f-4e87-ac45-4f16c8c4a525} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExactLow();) 2025.03.31 19:06:10.394349 [ 3830 ] {65acfeee-7e9f-4e87-ac45-4f16c8c4a525} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.409259 [ 3830 ] {bacbc048-ce69-4257-878b-b78e97803756} executeQuery: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileExactWeighted();) 2025.03.31 19:06:10.410916 [ 3830 ] {bacbc048-ce69-4257-878b-b78e97803756} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.426944 [ 3830 ] {6f623f18-72dc-449c-9c60-3ca6daea8ef4} executeQuery: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileGK();) 2025.03.31 19:06:10.428653 [ 3830 ] {6f623f18-72dc-449c-9c60-3ca6daea8ef4} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.444294 [ 3830 ] {63b767cb-c6c8-4f5d-8255-9821c15b28ed} executeQuery: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileInterpolatedWeighted();) 2025.03.31 19:06:10.504079 [ 3830 ] {63b767cb-c6c8-4f5d-8255-9821c15b28ed} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.520618 [ 3830 ] {704a7798-2dc3-4290-80bb-6c257c7cf13d} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileTDigest();) 2025.03.31 19:06:10.522437 [ 3830 ] {704a7798-2dc3-4290-80bb-6c257c7cf13d} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.537041 [ 3830 ] {a0dc96f3-4714-48a1-87eb-f3b086c6e387} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileTDigestWeighted();) 2025.03.31 19:06:10.538734 [ 3830 ] {a0dc96f3-4714-48a1-87eb-f3b086c6e387} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.554124 [ 3830 ] {5c75fefe-78a8-45b4-b033-4da71aeb4e75} executeQuery: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileTiming();) 2025.03.31 19:06:10.555817 [ 3830 ] {5c75fefe-78a8-45b4-b033-4da71aeb4e75} TCPHandler: Code: 35. DB::Exception: Aggregate function quantileTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:10.614871 [ 3830 ] {2308f72d-d9ed-4c28-b342-bfe879e54f09} executeQuery: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantileTimingWeighted();) 2025.03.31 19:06:10.616385 [ 3830 ] {2308f72d-d9ed-4c28-b342-bfe879e54f09} TCPHandler: Code: 42. DB::Exception: Aggregate function quantileTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.657555 [ 3830 ] {dac38212-91f8-42b8-b2d5-a4459f05d97b} executeQuery: Code: 35. DB::Exception: Aggregate function quantiles requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantiles();) 2025.03.31 19:06:10.659258 [ 3830 ] {dac38212-91f8-42b8-b2d5-a4459f05d97b} TCPHandler: Code: 35. DB::Exception: Aggregate function quantiles requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:10.673293 [ 3830 ] {23b80a7a-12ff-4e2d-a37d-5948651e3b45} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesBFloat16();) 2025.03.31 19:06:10.674740 [ 3830 ] {23b80a7a-12ff-4e2d-a37d-5948651e3b45} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesBFloat16 requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.690154 [ 3830 ] {23152d42-2da0-4e3a-9a79-24857d448d2c} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesBFloat16Weighted();) 2025.03.31 19:06:10.691538 [ 3830 ] {23152d42-2da0-4e3a-9a79-24857d448d2c} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesBFloat16Weighted requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:10.706469 [ 3830 ] {2d8c411f-6eff-446b-a3bb-12f39c3bd5b2} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesDD();) 2025.03.31 19:06:10.708263 [ 3830 ] {2d8c411f-6eff-446b-a3bb-12f39c3bd5b2} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesDD requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:10.724302 [ 3830 ] {1ad8cbcf-b367-4775-9c96-9c197f7a4465} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesDeterministic();) 2025.03.31 19:06:10.726086 [ 3830 ] {1ad8cbcf-b367-4775-9c96-9c197f7a4465} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesDeterministic requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.741045 [ 3830 ] {ca99e37c-a9ef-45dc-8bf1-43b4b8c566bb} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExact();) 2025.03.31 19:06:10.742901 [ 3830 ] {ca99e37c-a9ef-45dc-8bf1-43b4b8c566bb} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExact requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.758867 [ 3830 ] {5acccf4d-423d-4c7d-b5bf-c9a1fd27a4d8} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExactExclusive();) 2025.03.31 19:06:10.760661 [ 3830 ] {5acccf4d-423d-4c7d-b5bf-c9a1fd27a4d8} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExactExclusive requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:10.912201 [ 3830 ] {324bce10-f4c7-4e7b-ad21-215d60eab0c2} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExactHigh();) 2025.03.31 19:06:10.914234 [ 3830 ] {324bce10-f4c7-4e7b-ad21-215d60eab0c2} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesExactHigh requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:10.930188 [ 3830 ] {4fe69ff1-daf4-44ef-a026-5fce3b37f923} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExactInclusive();) 2025.03.31 19:06:10.931713 [ 3830 ] {4fe69ff1-daf4-44ef-a026-5fce3b37f923} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesExactInclusive requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:10.946437 [ 3830 ] {3fc08c27-9db3-4ffb-a069-f9216d7b14e9} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExactLow();) 2025.03.31 19:06:10.947907 [ 3830 ] {3fc08c27-9db3-4ffb-a069-f9216d7b14e9} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExactLow requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.036336 [ 3830 ] {9c63e80e-3f46-402a-abad-5006579b85da} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesExactWeighted();) 2025.03.31 19:06:11.037984 [ 3830 ] {9c63e80e-3f46-402a-abad-5006579b85da} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesExactWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.053077 [ 3830 ] {cafae86f-917b-4f32-870d-1f5b5093b711} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesGK();) 2025.03.31 19:06:11.054679 [ 3830 ] {cafae86f-917b-4f32-870d-1f5b5093b711} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesGK requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.071404 [ 3830 ] {83574413-465a-4a6d-9b05-b02c9fc96621} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesInterpolatedWeighted();) 2025.03.31 19:06:11.073238 [ 3830 ] {83574413-465a-4a6d-9b05-b02c9fc96621} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesInterpolatedWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.088067 [ 3830 ] {2bb2d66b-238d-4bc2-9c07-8623fffbd7a9} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesTDigest();) 2025.03.31 19:06:11.089457 [ 3830 ] {2bb2d66b-238d-4bc2-9c07-8623fffbd7a9} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesTDigest requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.104039 [ 3830 ] {9b77d415-ba69-4d24-9788-18973f5161d8} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesTDigestWeighted();) 2025.03.31 19:06:11.105567 [ 3830 ] {9b77d415-ba69-4d24-9788-18973f5161d8} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesTDigestWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.119422 [ 3830 ] {708f2553-f855-4cc3-ae99-0c17a7216844} executeQuery: Code: 35. DB::Exception: Aggregate function quantilesTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesTiming();) 2025.03.31 19:06:11.120934 [ 3830 ] {708f2553-f855-4cc3-ae99-0c17a7216844} TCPHandler: Code: 35. DB::Exception: Aggregate function quantilesTiming requires at least one argument. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:11.134429 [ 3830 ] {727f1d4d-3740-4606-b351-a95d8d6b1a41} executeQuery: Code: 42. DB::Exception: Aggregate function quantilesTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT quantilesTimingWeighted();) 2025.03.31 19:06:11.135860 [ 3830 ] {727f1d4d-3740-4606-b351-a95d8d6b1a41} TCPHandler: Code: 42. DB::Exception: Aggregate function quantilesTimingWeighted requires at least one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.175488 [ 3830 ] {aa9a503f-355d-451c-9306-003adb9bf028} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 0, should be 1: In scope SELECT queryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT queryString();) 2025.03.31 19:06:11.177092 [ 3830 ] {aa9a503f-355d-451c-9306-003adb9bf028} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 0, should be 1: In scope SELECT queryString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.191838 [ 3830 ] {19a54ee9-5184-4683-8b49-7002fa50fd9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT queryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT queryStringAndFragment();) 2025.03.31 19:06:11.193407 [ 3830 ] {19a54ee9-5184-4683-8b49-7002fa50fd9e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 0, should be 1: In scope SELECT queryStringAndFragment(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.237823 [ 3830 ] {7adf4688-0b62-480d-bd65-31df4a81ff77} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 0, should be 1: In scope SELECT radians(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT radians();) 2025.03.31 19:06:11.239316 [ 3830 ] {7adf4688-0b62-480d-bd65-31df4a81ff77} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 0, should be 1: In scope SELECT radians(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.350653 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:11.390072 [ 3830 ] {03422378-06db-4edc-8fb7-7284d082643b} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randBernoulli();) 2025.03.31 19:06:11.391500 [ 3830 ] {03422378-06db-4edc-8fb7-7284d082643b} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randBernoulli. Should be 1 or 2: In scope SELECT randBernoulli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.473988 [ 3830 ] {c077f3b6-24d3-417e-9cad-063c3b409cb2} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randBinomial. Should be 2 or 3: In scope SELECT randBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randBinomial();) 2025.03.31 19:06:11.475386 [ 3830 ] {c077f3b6-24d3-417e-9cad-063c3b409cb2} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randBinomial. Should be 2 or 3: In scope SELECT randBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.526629 [ 3830 ] {7a71fb30-6b1a-4489-a2f9-38186239101c} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randChiSquared();) 2025.03.31 19:06:11.528065 [ 3830 ] {7a71fb30-6b1a-4489-a2f9-38186239101c} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randChiSquared. Should be 1 or 2: In scope SELECT randChiSquared(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.613264 [ 3830 ] {c03f63c9-7225-45cf-b8bf-20ae89731385} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randExponential();) 2025.03.31 19:06:11.614913 [ 3830 ] {c03f63c9-7225-45cf-b8bf-20ae89731385} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randExponential. Should be 1 or 2: In scope SELECT randExponential(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.628654 [ 3830 ] {a7807c35-53db-4053-b4bf-7f69372e7496} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randFisherF. Should be 2 or 3: In scope SELECT randFisherF(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randFisherF();) 2025.03.31 19:06:11.630198 [ 3830 ] {a7807c35-53db-4053-b4bf-7f69372e7496} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randFisherF. Should be 2 or 3: In scope SELECT randFisherF(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.646487 [ 3830 ] {706cae00-f1b1-448c-a2a0-2693c71d38b3} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randLogNormal. Should be 2 or 3: In scope SELECT randLogNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randLogNormal();) 2025.03.31 19:06:11.648271 [ 3830 ] {706cae00-f1b1-448c-a2a0-2693c71d38b3} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randLogNormal. Should be 2 or 3: In scope SELECT randLogNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.678702 [ 3830 ] {361c0e57-0c42-4c6e-89db-c1d2df93cd29} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randNegativeBinomial. Should be 2 or 3: In scope SELECT randNegativeBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randNegativeBinomial();) 2025.03.31 19:06:11.680271 [ 3830 ] {361c0e57-0c42-4c6e-89db-c1d2df93cd29} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randNegativeBinomial. Should be 2 or 3: In scope SELECT randNegativeBinomial(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.694420 [ 3830 ] {1740a08b-9022-4d0c-8cbb-6776c52f29da} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randNormal. Should be 2 or 3: In scope SELECT randNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randNormal();) 2025.03.31 19:06:11.695866 [ 3830 ] {1740a08b-9022-4d0c-8cbb-6776c52f29da} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randNormal. Should be 2 or 3: In scope SELECT randNormal(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.712225 [ 3830 ] {7be05637-34a7-4b26-b17a-c480be697acf} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randPoisson();) 2025.03.31 19:06:11.714278 [ 3830 ] {7be05637-34a7-4b26-b17a-c480be697acf} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randPoisson. Should be 1 or 2: In scope SELECT randPoisson(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.728210 [ 3830 ] {35264dc8-e66b-4c49-8a44-e908a76e3c81} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randStudentT();) 2025.03.31 19:06:11.730012 [ 3830 ] {35264dc8-e66b-4c49-8a44-e908a76e3c81} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randStudentT. Should be 1 or 2: In scope SELECT randStudentT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.743850 [ 3830 ] {ca47ed42-0ef4-4f49-aae9-bb7249b1447b} executeQuery: Code: 42. DB::Exception: Wrong number of arguments for function randUniform. Should be 2 or 3: In scope SELECT randUniform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randUniform();) 2025.03.31 19:06:11.745321 [ 3830 ] {ca47ed42-0ef4-4f49-aae9-bb7249b1447b} TCPHandler: Code: 42. DB::Exception: Wrong number of arguments for function randUniform. Should be 2 or 3: In scope SELECT randUniform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.770776 [ 3830 ] {560bfaa6-56ce-4a1a-a21b-f1b64c9ae184} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 0, should be 1: In scope SELECT randomFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randomFixedString();) 2025.03.31 19:06:11.772274 [ 3830 ] {560bfaa6-56ce-4a1a-a21b-f1b64c9ae184} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 0, should be 1: In scope SELECT randomFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.785498 [ 3830 ] {6162d454-fbd7-423b-a8e5-92c1302cec00} executeQuery: Code: 42. DB::Exception: Function randomPrintableASCII requires at least one argument: the size of resulting string: In scope SELECT randomPrintableASCII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randomPrintableASCII();) 2025.03.31 19:06:11.787114 [ 3830 ] {6162d454-fbd7-423b-a8e5-92c1302cec00} TCPHandler: Code: 42. DB::Exception: Function randomPrintableASCII requires at least one argument: the size of resulting string: In scope SELECT randomPrintableASCII(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.801062 [ 3830 ] {cbc94744-8d49-4c25-9fed-09a80c9a6239} executeQuery: Code: 42. DB::Exception: Function randomString requires at least one argument: the size of resulting string: In scope SELECT randomString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randomString();) 2025.03.31 19:06:11.802741 [ 3830 ] {cbc94744-8d49-4c25-9fed-09a80c9a6239} TCPHandler: Code: 42. DB::Exception: Function randomString requires at least one argument: the size of resulting string: In scope SELECT randomString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.853889 [ 3830 ] {31ecfe04-6d85-489b-ac38-85dd2e10b831} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 0, should be 1: In scope SELECT randomStringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT randomStringUTF8();) 2025.03.31 19:06:11.856725 [ 3830 ] {31ecfe04-6d85-489b-ac38-85dd2e10b831} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 0, should be 1: In scope SELECT randomStringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:11.952633 [ 3830 ] {ec47a351-464a-4cb9-bd2d-afe7bec61bbd} executeQuery: Code: 42. DB::Exception: Function range needs 1..3 arguments; passed 0.: In scope SELECT range(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT range();) 2025.03.31 19:06:11.954480 [ 3830 ] {ec47a351-464a-4cb9-bd2d-afe7bec61bbd} TCPHandler: Code: 42. DB::Exception: Function range needs 1..3 arguments; passed 0.: In scope SELECT range(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.008916 [ 3830 ] {e0750b0e-2921-4dea-9c3e-4dc59ef4d6bc} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rank();) 2025.03.31 19:06:12.011240 [ 3830 ] {e0750b0e-2921-4dea-9c3e-4dc59ef4d6bc} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.03.31 19:06:12.043042 [ 3830 ] {41ddf5ac-c81f-443f-8da2-8c414b844b9e} executeQuery: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rankCorr();) 2025.03.31 19:06:12.044614 [ 3830 ] {41ddf5ac-c81f-443f-8da2-8c414b844b9e} TCPHandler: Code: 42. DB::Exception: Aggregate function rankCorr requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.058873 [ 3830 ] {4c4d5f0f-e117-4558-a334-4aed77b7ccab} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTLineString();) 2025.03.31 19:06:12.060312 [ 3830 ] {4c4d5f0f-e117-4558-a334-4aed77b7ccab} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.076646 [ 3830 ] {a439605c-ae47-4c16-a347-1453ccc7079e} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTMultiLineString();) 2025.03.31 19:06:12.078378 [ 3830 ] {a439605c-ae47-4c16-a347-1453ccc7079e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiLineString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.094949 [ 3830 ] {ea20916b-83a3-43a7-8681-c57053cf5eef} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTMultiPolygon();) 2025.03.31 19:06:12.097890 [ 3830 ] {ea20916b-83a3-43a7-8681-c57053cf5eef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTMultiPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.111625 [ 3830 ] {ccf5dae3-3377-4999-80be-2b59488b52c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 0, should be 1: In scope SELECT readWKTPoint(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTPoint();) 2025.03.31 19:06:12.113084 [ 3830 ] {ccf5dae3-3377-4999-80be-2b59488b52c0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 0, should be 1: In scope SELECT readWKTPoint(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.127083 [ 3830 ] {cf674ca7-e8fa-48f5-b325-12391c551f0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTPolygon();) 2025.03.31 19:06:12.128564 [ 3830 ] {cf674ca7-e8fa-48f5-b325-12391c551f0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 0, should be 1: In scope SELECT readWKTPolygon(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.144490 [ 3830 ] {2bec8fb0-7ff1-41b1-938d-d6ac34df62a4} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 0, should be 1: In scope SELECT readWKTRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT readWKTRing();) 2025.03.31 19:06:12.146217 [ 3830 ] {2bec8fb0-7ff1-41b1-938d-d6ac34df62a4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 0, should be 1: In scope SELECT readWKTRing(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.261146 [ 3830 ] {e0964b8f-30d7-4870-9de6-38fa03ed1482} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT regexpExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regexpExtract();) 2025.03.31 19:06:12.262968 [ 3830 ] {e0964b8f-30d7-4870-9de6-38fa03ed1482} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpExtract doesn't match: passed 0: In scope SELECT regexpExtract(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.278411 [ 3830 ] {f95b7a79-5b71-41f8-904c-8cb4f3a5694e} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 0, should be 1: In scope SELECT regexpQuoteMeta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regexpQuoteMeta();) 2025.03.31 19:06:12.280155 [ 3830 ] {f95b7a79-5b71-41f8-904c-8cb4f3a5694e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 0, should be 1: In scope SELECT regexpQuoteMeta(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.390957 [ 3830 ] {f3bde461-d7b2-4260-9585-afd80d40d4cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionHierarchy();) 2025.03.31 19:06:12.392730 [ 3830 ] {f3bde461-d7b2-4260-9585-afd80d40d4cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionHierarchy doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionHierarchy(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.407586 [ 3830 ] {fadab525-fae3-4829-8771-30c9bbee7946} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionIn doesn't match: passed 0, should be 2 or 3.: In scope SELECT regionIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionIn();) 2025.03.31 19:06:12.409078 [ 3830 ] {fadab525-fae3-4829-8771-30c9bbee7946} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionIn doesn't match: passed 0, should be 2 or 3.: In scope SELECT regionIn(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.425900 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:12.432176 [ 3830 ] {f1d37163-377c-4a75-95ed-8dd3b163907a} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToArea(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToArea();) 2025.03.31 19:06:12.433961 [ 3830 ] {f1d37163-377c-4a75-95ed-8dd3b163907a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToArea doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToArea(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.447609 [ 3830 ] {4f549949-8a05-445e-a85d-a37d4b0d5519} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToCity();) 2025.03.31 19:06:12.449058 [ 3830 ] {4f549949-8a05-445e-a85d-a37d4b0d5519} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCity doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCity(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.464970 [ 3830 ] {758103ec-5c9c-467b-bcdf-be5a665d4620} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToContinent();) 2025.03.31 19:06:12.466830 [ 3830 ] {758103ec-5c9c-467b-bcdf-be5a665d4620} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.482811 [ 3830 ] {a01a258e-a312-476b-9260-d9349a647df1} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCountry(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToCountry();) 2025.03.31 19:06:12.484434 [ 3830 ] {a01a258e-a312-476b-9260-d9349a647df1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToCountry doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToCountry(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.499044 [ 3830 ] {cf401921-9099-4943-a327-d753d409dbde} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToDistrict(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToDistrict();) 2025.03.31 19:06:12.500606 [ 3830 ] {cf401921-9099-4943-a327-d753d409dbde} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToDistrict doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToDistrict(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.514689 [ 3830 ] {2e5da554-3a9a-4818-8fc9-af9b485849f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToName();) 2025.03.31 19:06:12.516206 [ 3830 ] {2e5da554-3a9a-4818-8fc9-af9b485849f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToName doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.530985 [ 3830 ] {d7b77fdc-7f06-4534-bfdf-2d8bdbe5533a} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToPopulation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToPopulation();) 2025.03.31 19:06:12.532424 [ 3830 ] {d7b77fdc-7f06-4534-bfdf-2d8bdbe5533a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToPopulation doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToPopulation(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.548009 [ 3830 ] {71118839-acda-456e-b5bf-504f9f1c5197} executeQuery: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToTopContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT regionToTopContinent();) 2025.03.31 19:06:12.549493 [ 3830 ] {71118839-acda-456e-b5bf-504f9f1c5197} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regionToTopContinent doesn't match: passed 0, should be 1 or 2.: In scope SELECT regionToTopContinent(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.563387 [ 3830 ] {7bc5dae0-9003-46e8-8453-5d61e2fe046d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 0, should be 2: In scope SELECT reinterpret(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpret();) 2025.03.31 19:06:12.564872 [ 3830 ] {7bc5dae0-9003-46e8-8453-5d61e2fe046d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpret doesn't match: passed 0, should be 2: In scope SELECT reinterpret(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.579997 [ 3830 ] {9af0820e-0875-4a2d-9836-86c98a691086} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsDate();) 2025.03.31 19:06:12.581949 [ 3830 ] {9af0820e-0875-4a2d-9836-86c98a691086} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.596729 [ 3830 ] {068c55be-2bb0-4d70-848b-a795414fce5a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsDateTime();) 2025.03.31 19:06:12.598354 [ 3830 ] {068c55be-2bb0-4d70-848b-a795414fce5a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.612201 [ 3830 ] {970e999e-6aa0-4a49-b003-30ed4c710322} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsFixedString();) 2025.03.31 19:06:12.614077 [ 3830 ] {970e999e-6aa0-4a49-b003-30ed4c710322} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.628512 [ 3830 ] {be89b860-c622-4ed0-83a0-93bfaf85620b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsFloat32();) 2025.03.31 19:06:12.630395 [ 3830 ] {be89b860-c622-4ed0-83a0-93bfaf85620b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.645244 [ 3830 ] {321c5606-7cb3-4579-b016-84b723c77f85} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsFloat64();) 2025.03.31 19:06:12.646980 [ 3830 ] {321c5606-7cb3-4579-b016-84b723c77f85} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.662578 [ 3830 ] {0166040b-e867-419c-8475-bb0fce823d5b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt128();) 2025.03.31 19:06:12.664110 [ 3830 ] {0166040b-e867-419c-8475-bb0fce823d5b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.678804 [ 3830 ] {70a20253-a117-4322-bf80-437d033468c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt16();) 2025.03.31 19:06:12.680635 [ 3830 ] {70a20253-a117-4322-bf80-437d033468c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.696974 [ 3830 ] {3287756b-2fec-4e3b-864c-eb2c95efb767} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt256();) 2025.03.31 19:06:12.698893 [ 3830 ] {3287756b-2fec-4e3b-864c-eb2c95efb767} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.712822 [ 3830 ] {e4d8961a-eafd-45e7-b591-9d3eef7c4a48} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt32();) 2025.03.31 19:06:12.714743 [ 3830 ] {e4d8961a-eafd-45e7-b591-9d3eef7c4a48} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.790624 [ 3830 ] {9361162e-e0a4-4501-9d75-933810c347b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt64();) 2025.03.31 19:06:12.792229 [ 3830 ] {9361162e-e0a4-4501-9d75-933810c347b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.806080 [ 3830 ] {255886f6-607c-4d09-9272-9f1da42ee388} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsInt8();) 2025.03.31 19:06:12.808149 [ 3830 ] {255886f6-607c-4d09-9272-9f1da42ee388} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.822879 [ 3830 ] {526989ef-03bd-463c-abfc-e815e33f6419} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsString();) 2025.03.31 19:06:12.824550 [ 3830 ] {526989ef-03bd-463c-abfc-e815e33f6419} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.912048 [ 3830 ] {c829721b-a668-44cc-a082-decbb4f77506} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt128();) 2025.03.31 19:06:12.913908 [ 3830 ] {c829721b-a668-44cc-a082-decbb4f77506} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.929505 [ 3830 ] {709d851e-f77d-44ed-8ef5-7b6e9d95e7ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt16();) 2025.03.31 19:06:12.962973 [ 3830 ] {709d851e-f77d-44ed-8ef5-7b6e9d95e7ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.978338 [ 3830 ] {ac6d590a-3286-4c9c-a9ba-faad7583de81} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt256();) 2025.03.31 19:06:12.979915 [ 3830 ] {ac6d590a-3286-4c9c-a9ba-faad7583de81} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:12.995138 [ 3830 ] {7603656d-889b-4721-970d-1660c3fbec27} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt32();) 2025.03.31 19:06:12.996668 [ 3830 ] {7603656d-889b-4721-970d-1660c3fbec27} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.011697 [ 3830 ] {097513ff-9604-4190-9268-347dc0466e35} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt64();) 2025.03.31 19:06:13.013434 [ 3830 ] {097513ff-9604-4190-9268-347dc0466e35} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.121621 [ 3830 ] {dec6e2c6-a623-4025-bb60-dbaf1f286a5d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUInt8();) 2025.03.31 19:06:13.123646 [ 3830 ] {dec6e2c6-a623-4025-bb60-dbaf1f286a5d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.138921 [ 3830 ] {473dc95c-9d11-4876-9c44-6dd0a7dd9376} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reinterpretAsUUID();) 2025.03.31 19:06:13.140707 [ 3830 ] {473dc95c-9d11-4876-9c44-6dd0a7dd9376} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 0, should be 1: In scope SELECT reinterpretAsUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.155790 [ 3830 ] {29241569-a63f-42c8-a7fa-c87cc734f912} executeQuery: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 0, should be 2: In scope SELECT repeat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT repeat();) 2025.03.31 19:06:13.157542 [ 3830 ] {29241569-a63f-42c8-a7fa-c87cc734f912} TCPHandler: Code: 42. DB::Exception: Number of arguments for function repeat doesn't match: passed 0, should be 2: In scope SELECT repeat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.180905 [ 3830 ] {b3dc2f3e-fabe-4899-9867-b4779b211063} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replace();) 2025.03.31 19:06:13.182873 [ 3830 ] {b3dc2f3e-fabe-4899-9867-b4779b211063} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.197461 [ 3830 ] {e09c807b-2a91-4d17-8e95-06887ff67717} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replaceAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replaceAll();) 2025.03.31 19:06:13.199244 [ 3830 ] {e09c807b-2a91-4d17-8e95-06887ff67717} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 0, should be 3: In scope SELECT replaceAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.213436 [ 3830 ] {ca5279e2-297b-4cd6-b23e-51498dc23ba8} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 0, should be 3: In scope SELECT replaceOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replaceOne();) 2025.03.31 19:06:13.215033 [ 3830 ] {ca5279e2-297b-4cd6-b23e-51498dc23ba8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 0, should be 3: In scope SELECT replaceOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.229600 [ 3830 ] {93920343-49f3-436d-b6df-53f382687297} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replaceRegexpAll();) 2025.03.31 19:06:13.231330 [ 3830 ] {93920343-49f3-436d-b6df-53f382687297} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpAll(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.246572 [ 3830 ] {d06b78a2-81c7-4fc5-85ca-a024c1bde15f} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replaceRegexpOne();) 2025.03.31 19:06:13.248258 [ 3830 ] {d06b78a2-81c7-4fc5-85ca-a024c1bde15f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 0, should be 3: In scope SELECT replaceRegexpOne(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.263737 [ 3830 ] {ab1da22e-4eb6-42f6-aba7-161a621597d5} executeQuery: Code: 35. DB::Exception: Function replicate expect at least two arguments, got 0: In scope SELECT replicate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT replicate();) 2025.03.31 19:06:13.265507 [ 3830 ] {ab1da22e-4eb6-42f6-aba7-161a621597d5} TCPHandler: Code: 35. DB::Exception: Function replicate expect at least two arguments, got 0: In scope SELECT replicate(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:13.279864 [ 3830 ] {f5e53d72-26b5-45db-b300-8124069bacff} executeQuery: Code: 42. DB::Exception: Not enough event arguments for aggregate function retention. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT retention();) 2025.03.31 19:06:13.281510 [ 3830 ] {f5e53d72-26b5-45db-b300-8124069bacff} TCPHandler: Code: 42. DB::Exception: Not enough event arguments for aggregate function retention. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.295585 [ 3830 ] {a2f854da-7d3f-4c8c-bb95-e9ab3e1acc68} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 0, should be 1: In scope SELECT reverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reverse();) 2025.03.31 19:06:13.297100 [ 3830 ] {a2f854da-7d3f-4c8c-bb95-e9ab3e1acc68} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 0, should be 1: In scope SELECT reverse(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.380643 [ 3830 ] {3947373c-9e38-4bf1-b2dd-0c1a8e21a11b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 0, should be 1: In scope SELECT reverseUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT reverseUTF8();) 2025.03.31 19:06:13.449134 [ 3830 ] {3947373c-9e38-4bf1-b2dd-0c1a8e21a11b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 0, should be 1: In scope SELECT reverseUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.463549 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:13.528734 [ 3830 ] {2397f8e9-5531-4b9d-974d-087a10bae952} executeQuery: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 0, should be 2: In scope SELECT right(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT right();) 2025.03.31 19:06:13.530354 [ 3830 ] {2397f8e9-5531-4b9d-974d-087a10bae952} TCPHandler: Code: 42. DB::Exception: Number of arguments for function right doesn't match: passed 0, should be 2: In scope SELECT right(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.544941 [ 3830 ] {fe621460-cacf-4ca8-92da-55ad807cdf50} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rightPad();) 2025.03.31 19:06:13.546583 [ 3830 ] {fe621460-cacf-4ca8-92da-55ad807cdf50} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.559616 [ 3830 ] {1b2f2a90-91e9-4bbf-8eed-f2eaf63cd49a} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rightPadUTF8();) 2025.03.31 19:06:13.561057 [ 3830 ] {1b2f2a90-91e9-4bbf-8eed-f2eaf63cd49a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPadUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT rightPadUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.606782 [ 3830 ] {39ecc6aa-41a5-4012-aef6-9b00d7983aa1} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 0, should be 2: In scope SELECT rightUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rightUTF8();) 2025.03.31 19:06:13.608240 [ 3830 ] {39ecc6aa-41a5-4012-aef6-9b00d7983aa1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightUTF8 doesn't match: passed 0, should be 2: In scope SELECT rightUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.721108 [ 3830 ] {d70933be-85b1-41c5-bb84-48ab64ee1e40} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT round(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT round();) 2025.03.31 19:06:13.722874 [ 3830 ] {d70933be-85b1-41c5-bb84-48ab64ee1e40} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'round'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT round(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.738217 [ 3830 ] {456cb08f-8e40-48a3-9503-a02433ad59e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 0, should be 1: In scope SELECT roundAge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT roundAge();) 2025.03.31 19:06:13.742502 [ 3830 ] {456cb08f-8e40-48a3-9503-a02433ad59e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 0, should be 1: In scope SELECT roundAge(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.756741 [ 3830 ] {2ad2f8ef-8dcf-4b89-8cc7-a7f1c0c97d0b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT roundBankers(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT roundBankers();) 2025.03.31 19:06:13.758477 [ 3830 ] {2ad2f8ef-8dcf-4b89-8cc7-a7f1c0c97d0b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'roundBankers'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT roundBankers(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.774693 [ 3830 ] {38b2bbbb-043f-48fe-9cb7-341433a55627} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 0, should be 2: In scope SELECT roundDown(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT roundDown();) 2025.03.31 19:06:13.776394 [ 3830 ] {38b2bbbb-043f-48fe-9cb7-341433a55627} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDown doesn't match: passed 0, should be 2: In scope SELECT roundDown(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.791970 [ 3830 ] {5a369dd0-eac4-4128-8b5b-e1398bb63a8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 0, should be 1: In scope SELECT roundDuration(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT roundDuration();) 2025.03.31 19:06:13.793908 [ 3830 ] {5a369dd0-eac4-4128-8b5b-e1398bb63a8d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 0, should be 1: In scope SELECT roundDuration(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.857551 [ 3830 ] {e50c0a86-2dcf-4d14-92b8-e5fe59857445} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 0, should be 1: In scope SELECT roundToExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT roundToExp2();) 2025.03.31 19:06:13.859818 [ 3830 ] {e50c0a86-2dcf-4d14-92b8-e5fe59857445} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 0, should be 1: In scope SELECT roundToExp2(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.929199 [ 3830 ] {135147f8-f66f-4b1c-ae1e-5caa5b363b61} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT row_number();) 2025.03.31 19:06:13.931604 [ 3830 ] {135147f8-f66f-4b1c-ae1e-5caa5b363b61} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.03.31 19:06:13.946215 [ 3830 ] {c3606617-0d0b-4ac5-88e9-abd692e6adeb} executeQuery: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT rpad();) 2025.03.31 19:06:13.947746 [ 3830 ] {c3606617-0d0b-4ac5-88e9-abd692e6adeb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rightPad doesn't match: passed 0, should be 2 or 3: In scope SELECT rpad(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:13.963609 [ 3830 ] {3684a0bd-5c3f-44ac-84b9-54bfd50d14f6} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT runningAccumulate();) 2025.03.31 19:06:13.965959 [ 3830 ] {3684a0bd-5c3f-44ac-84b9-54bfd50d14f6} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.03.31 19:06:14.066137 [ 3830 ] {05dabcde-7521-4e00-ae9a-8a67faec1b37} executeQuery: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 0, should be 2: In scope SELECT runningConcurrency(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT runningConcurrency();) 2025.03.31 19:06:14.067587 [ 3830 ] {05dabcde-7521-4e00-ae9a-8a67faec1b37} TCPHandler: Code: 42. DB::Exception: Number of arguments for function runningConcurrency doesn't match: passed 0, should be 2: In scope SELECT runningConcurrency(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.082723 [ 3830 ] {71bd8172-ad18-4a64-a212-5a80ba9c000a} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT runningDifference();) 2025.03.31 19:06:14.086209 [ 3830 ] {71bd8172-ad18-4a64-a212-5a80ba9c000a} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.03.31 19:06:14.101501 [ 3830 ] {269e227e-df82-4fd5-b588-20d56e658e12} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT runningDifferenceStartingWithFirstValue();) 2025.03.31 19:06:14.103148 [ 3830 ] {269e227e-df82-4fd5-b588-20d56e658e12} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.03.31 19:06:14.119875 [ 3830 ] {b66a1158-2521-4901-a162-5040910379af} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 0, should be 3: In scope SELECT s2CapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2CapContains();) 2025.03.31 19:06:14.121653 [ 3830 ] {b66a1158-2521-4901-a162-5040910379af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 0, should be 3: In scope SELECT s2CapContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.135676 [ 3830 ] {bdac9ee9-0f98-475f-8de5-31f5d1a5a984} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 0, should be 4: In scope SELECT s2CapUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2CapUnion();) 2025.03.31 19:06:14.137130 [ 3830 ] {bdac9ee9-0f98-475f-8de5-31f5d1a5a984} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 0, should be 4: In scope SELECT s2CapUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.149913 [ 3830 ] {fd197d2d-fb04-4995-bf30-042a5970d746} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 0, should be 2: In scope SELECT s2CellsIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2CellsIntersect();) 2025.03.31 19:06:14.151428 [ 3830 ] {fd197d2d-fb04-4995-bf30-042a5970d746} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CellsIntersect doesn't match: passed 0, should be 2: In scope SELECT s2CellsIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.165580 [ 3830 ] {92232063-1dc7-423d-b5fd-9f9dd068e8f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 0, should be 1: In scope SELECT s2GetNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2GetNeighbors();) 2025.03.31 19:06:14.167128 [ 3830 ] {92232063-1dc7-423d-b5fd-9f9dd068e8f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 0, should be 1: In scope SELECT s2GetNeighbors(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.257331 [ 3830 ] {947603f6-30d6-4068-9612-dbf6621c43c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 0, should be 3: In scope SELECT s2RectAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2RectAdd();) 2025.03.31 19:06:14.259044 [ 3830 ] {947603f6-30d6-4068-9612-dbf6621c43c0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 0, should be 3: In scope SELECT s2RectAdd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.272227 [ 3830 ] {f2c1749d-e860-4969-ac18-cfc9317285b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 0, should be 3: In scope SELECT s2RectContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2RectContains();) 2025.03.31 19:06:14.273658 [ 3830 ] {f2c1749d-e860-4969-ac18-cfc9317285b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 0, should be 3: In scope SELECT s2RectContains(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.324553 [ 3830 ] {33a9bdeb-3f33-40ec-87ac-f240590ea211} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 0, should be 4: In scope SELECT s2RectIntersection(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2RectIntersection();) 2025.03.31 19:06:14.328133 [ 3830 ] {33a9bdeb-3f33-40ec-87ac-f240590ea211} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 0, should be 4: In scope SELECT s2RectIntersection(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.342816 [ 3830 ] {4dc5868e-0b6e-444e-ae6c-2c21f2a88a1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 0, should be 4: In scope SELECT s2RectUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2RectUnion();) 2025.03.31 19:06:14.344457 [ 3830 ] {4dc5868e-0b6e-444e-ae6c-2c21f2a88a1f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 0, should be 4: In scope SELECT s2RectUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.495242 [ 3830 ] {0b135f5a-5a41-4db7-af9f-b3bea68f4820} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 0, should be 1: In scope SELECT s2ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT s2ToGeo();) 2025.03.31 19:06:14.496860 [ 3830 ] {0b135f5a-5a41-4db7-af9f-b3bea68f4820} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 0, should be 1: In scope SELECT s2ToGeo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.510673 [ 3830 ] {2f0457c9-0187-4793-9044-601b3a1b536e} executeQuery: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT scalarProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT scalarProduct();) 2025.03.31 19:06:14.512183 [ 3830 ] {2f0457c9-0187-4793-9044-601b3a1b536e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dotProduct doesn't match: passed 0, should be 2: In scope SELECT scalarProduct(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.573471 [ 3830 ] {c79fd57d-6fa4-4746-8248-09f1ef470343} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sequenceCount();) 2025.03.31 19:06:14.575094 [ 3830 ] {c79fd57d-6fa4-4746-8248-09f1ef470343} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.577925 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:14.664504 [ 3830 ] {00398549-fe0c-4204-ba9a-c01b092fbd5c} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sequenceMatch();) 2025.03.31 19:06:14.666330 [ 3830 ] {00398549-fe0c-4204-ba9a-c01b092fbd5c} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.681121 [ 3830 ] {2e843d24-7f1e-4504-ac2c-688cd3d64a84} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sequenceNextNode();) 2025.03.31 19:06:14.682934 [ 3830 ] {2e843d24-7f1e-4504-ac2c-688cd3d64a84} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.03.31 19:06:14.728645 [ 3830 ] {caec881c-67b8-4a93-acaf-b12cb7c32287} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 0, should be 2: In scope SELECT seriesDecomposeSTL(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT seriesDecomposeSTL();) 2025.03.31 19:06:14.730153 [ 3830 ] {caec881c-67b8-4a93-acaf-b12cb7c32287} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesDecomposeSTL doesn't match: passed 0, should be 2: In scope SELECT seriesDecomposeSTL(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.742574 [ 3830 ] {c5cfc657-9937-4694-94bd-b7ffe4b27db3} executeQuery: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 0.: In scope SELECT seriesOutliersDetectTukey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT seriesOutliersDetectTukey();) 2025.03.31 19:06:14.743884 [ 3830 ] {c5cfc657-9937-4694-94bd-b7ffe4b27db3} TCPHandler: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 0.: In scope SELECT seriesOutliersDetectTukey(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:14.848586 [ 3830 ] {5efcfa9d-4dcd-40d6-bd12-32968063b188} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 0, should be 1: In scope SELECT seriesPeriodDetectFFT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT seriesPeriodDetectFFT();) 2025.03.31 19:06:14.850242 [ 3830 ] {5efcfa9d-4dcd-40d6-bd12-32968063b188} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 0, should be 1: In scope SELECT seriesPeriodDetectFFT(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.114097 [ 3830 ] {a5ee1666-b2f2-4bf4-9da0-f9c62a4ec0a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 0, should be 1: In scope SELECT sigmoid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sigmoid();) 2025.03.31 19:06:15.118888 [ 3830 ] {a5ee1666-b2f2-4bf4-9da0-f9c62a4ec0a6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 0, should be 1: In scope SELECT sigmoid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.131563 [ 3830 ] {36a872a0-82a7-4db7-b722-8440d885e8d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 0, should be 1: In scope SELECT sign(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sign();) 2025.03.31 19:06:15.132967 [ 3830 ] {36a872a0-82a7-4db7-b722-8440d885e8d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 0, should be 1: In scope SELECT sign(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.145088 [ 3830 ] {1427c192-a420-4ccf-b1ec-275a9fe9b978} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractBool();) 2025.03.31 19:06:15.146486 [ 3830 ] {1427c192-a420-4ccf-b1ec-275a9fe9b978} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.158313 [ 3830 ] {cd490242-fdce-4039-9683-479ec31bd541} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractFloat();) 2025.03.31 19:06:15.159896 [ 3830 ] {cd490242-fdce-4039-9683-479ec31bd541} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.171472 [ 3830 ] {5e73b822-f322-4400-a999-7e32badc4a1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractInt();) 2025.03.31 19:06:15.172958 [ 3830 ] {5e73b822-f322-4400-a999-7e32badc4a1d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.256996 [ 3830 ] {2774c981-6f76-4fb4-966c-e9cf29eec989} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractRaw();) 2025.03.31 19:06:15.259095 [ 3830 ] {2774c981-6f76-4fb4-966c-e9cf29eec989} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.275161 [ 3830 ] {2b8464fd-4ebe-40a9-93a4-e1ef1e5880f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractString();) 2025.03.31 19:06:15.276883 [ 3830 ] {2b8464fd-4ebe-40a9-93a4-e1ef1e5880f7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.292018 [ 3830 ] {9d061fe1-4864-467e-9361-1477e7cfd112} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONExtractUInt();) 2025.03.31 19:06:15.293621 [ 3830 ] {9d061fe1-4864-467e-9361-1477e7cfd112} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT simpleJSONExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.331151 [ 3830 ] {be6afc63-2ff3-4c36-a043-7d3f2f3e5f9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT simpleJSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleJSONHas();) 2025.03.31 19:06:15.332923 [ 3830 ] {be6afc63-2ff3-4c36-a043-7d3f2f3e5f9e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT simpleJSONHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.347862 [ 3830 ] {89998950-212d-4632-a7f7-efba6193e586} executeQuery: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT simpleLinearRegression();) 2025.03.31 19:06:15.349464 [ 3830 ] {89998950-212d-4632-a7f7-efba6193e586} TCPHandler: Code: 42. DB::Exception: Aggregate function simpleLinearRegression requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.365209 [ 3830 ] {07b48390-ca59-4a8b-8d73-bd12026df72c} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 0, should be 1: In scope SELECT sin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sin();) 2025.03.31 19:06:15.374247 [ 3830 ] {07b48390-ca59-4a8b-8d73-bd12026df72c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 0, should be 1: In scope SELECT sin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.388594 [ 3830 ] {8f1f94e0-0621-4a5d-96cb-76f354be09e8} executeQuery: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT singleValueOrNull();) 2025.03.31 19:06:15.390523 [ 3830 ] {8f1f94e0-0621-4a5d-96cb-76f354be09e8} TCPHandler: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.406457 [ 3830 ] {99f7a8fa-ae55-4884-ad78-c2fb93501881} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 0, should be 1: In scope SELECT sinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sinh();) 2025.03.31 19:06:15.408249 [ 3830 ] {99f7a8fa-ae55-4884-ad78-c2fb93501881} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 0, should be 1: In scope SELECT sinh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.660482 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:15.822808 [ 3830 ] {c71d98b3-a59a-43e1-91a5-0adf7d823c5b} executeQuery: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT skewPop();) 2025.03.31 19:06:15.824827 [ 3830 ] {c71d98b3-a59a-43e1-91a5-0adf7d823c5b} TCPHandler: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.839925 [ 3830 ] {28e77b37-9b67-4906-aa74-7a5191a5e946} executeQuery: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT skewSamp();) 2025.03.31 19:06:15.841976 [ 3830 ] {28e77b37-9b67-4906-aa74-7a5191a5e946} TCPHandler: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.856290 [ 3830 ] {eef9a73f-6e9b-49bc-8efd-5dc74bb4440d} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 0, should be 1: In scope SELECT sleep(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sleep();) 2025.03.31 19:06:15.859904 [ 3830 ] {eef9a73f-6e9b-49bc-8efd-5dc74bb4440d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 0, should be 1: In scope SELECT sleep(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.872875 [ 3830 ] {5e7f3d2f-c2b7-4b89-80a5-075ad69fbe0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 0, should be 1: In scope SELECT sleepEachRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sleepEachRow();) 2025.03.31 19:06:15.874624 [ 3830 ] {5e7f3d2f-c2b7-4b89-80a5-075ad69fbe0c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 0, should be 1: In scope SELECT sleepEachRow(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:15.890130 [ 3830 ] {f9f68af2-fb62-48c3-89c5-4155c9fac8d3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT snowflakeIDToDateTime();) 2025.03.31 19:06:15.891760 [ 3830 ] {f9f68af2-fb62-48c3-89c5-4155c9fac8d3} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.004291 [ 3830 ] {85926165-b537-42e8-8ad2-402ee24f3981} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT snowflakeIDToDateTime64();) 2025.03.31 19:06:16.006455 [ 3830 ] {85926165-b537-42e8-8ad2-402ee24f3981} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeIDToDateTime64'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT snowflakeIDToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.023398 [ 3830 ] {d494883a-d30e-438a-b970-795fb3b7c978} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT snowflakeToDateTime();) 2025.03.31 19:06:16.025207 [ 3830 ] {d494883a-d30e-438a-b970-795fb3b7c978} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.039915 [ 3830 ] {800bb4c4-3209-43fd-8c4e-cc4e4b4020ac} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT snowflakeToDateTime64();) 2025.03.31 19:06:16.041626 [ 3830 ] {800bb4c4-3209-43fd-8c4e-cc4e4b4020ac} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'snowflakeToDateTime64'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT snowflakeToDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.056278 [ 3830 ] {097a6f92-b5f7-4052-be69-c6b7f8069c02} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 0, should be 1: In scope SELECT soundex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT soundex();) 2025.03.31 19:06:16.058011 [ 3830 ] {097a6f92-b5f7-4052-be69-c6b7f8069c02} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 0, should be 1: In scope SELECT soundex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.072611 [ 3830 ] {0bacfef5-4a71-452a-85f3-0a2e42f90fad} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 0, should be 1: In scope SELECT space(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT space();) 2025.03.31 19:06:16.074376 [ 3830 ] {0bacfef5-4a71-452a-85f3-0a2e42f90fad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 0, should be 1: In scope SELECT space(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.088828 [ 3830 ] {fff6fa84-3310-4a1a-a6e7-5c68d76b5964} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sparkBar();) 2025.03.31 19:06:16.090738 [ 3830 ] {fff6fa84-3310-4a1a-a6e7-5c68d76b5964} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.105336 [ 3830 ] {ab914d3d-5ca8-48a8-bc3e-658adffdd4d2} executeQuery: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sparkbar();) 2025.03.31 19:06:16.106850 [ 3830 ] {ab914d3d-5ca8-48a8-bc3e-658adffdd4d2} TCPHandler: Code: 42. DB::Exception: Aggregate function sparkbar requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.160847 [ 3830 ] {896ce3a2-489a-4fa4-9383-fa2ff2a2dfb5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByAlpha();) 2025.03.31 19:06:16.162675 [ 3830 ] {896ce3a2-489a-4fa4-9383-fa2ff2a2dfb5} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'alphaTokens'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.188394 [ 3830 ] {76fac2a0-b6f8-44df-ba90-8c4b5bc4bb30} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByChar'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByChar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByChar();) 2025.03.31 19:06:16.190005 [ 3830 ] {76fac2a0-b6f8-44df-ba90-8c4b5bc4bb30} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByChar'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByChar(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.202944 [ 3830 ] {16590b1f-e1fb-414d-87d2-17c4ebfae03c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByNonAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByNonAlpha();) 2025.03.31 19:06:16.204436 [ 3830 ] {16590b1f-e1fb-414d-87d2-17c4ebfae03c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByNonAlpha'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByNonAlpha(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.217330 [ 3830 ] {35968d04-591d-4cc9-8872-266c6a728785} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByRegexp'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByRegexp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByRegexp();) 2025.03.31 19:06:16.272182 [ 3830 ] {35968d04-591d-4cc9-8872-266c6a728785} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByRegexp'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByRegexp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.284941 [ 3830 ] {ce4beefa-df82-4e71-b96e-a631cf8c3e98} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByString'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByString();) 2025.03.31 19:06:16.286461 [ 3830 ] {ce4beefa-df82-4e71-b96e-a631cf8c3e98} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByString'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT splitByString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.300675 [ 3830 ] {7791f8ea-b634-4850-9e93-2b2e9c6f7670} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByWhitespace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT splitByWhitespace();) 2025.03.31 19:06:16.303788 [ 3830 ] {7791f8ea-b634-4850-9e93-2b2e9c6f7670} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'splitByWhitespace'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT splitByWhitespace(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.320095 [ 3830 ] {1ce692a5-46d8-45d9-ac92-6ded420f3857} executeQuery: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sqid();) 2025.03.31 19:06:16.321556 [ 3830 ] {1ce692a5-46d8-45d9-ac92-6ded420f3857} TCPHandler: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqid(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.340322 [ 3830 ] {3a288ae8-7fc3-42af-aaf8-4540ef2dd5e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 0, should be 1: In scope SELECT sqidDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sqidDecode();) 2025.03.31 19:06:16.342104 [ 3830 ] {3a288ae8-7fc3-42af-aaf8-4540ef2dd5e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 0, should be 1: In scope SELECT sqidDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.413160 [ 3830 ] {d9331197-0602-4ca0-a4ea-ba814f5a62bf} executeQuery: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqidEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sqidEncode();) 2025.03.31 19:06:16.414727 [ 3830 ] {d9331197-0602-4ca0-a4ea-ba814f5a62bf} TCPHandler: Code: 42. DB::Exception: Function sqidEncode requires at least one argument.: In scope SELECT sqidEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.429541 [ 3830 ] {b36653a3-1e78-4bef-ad9f-fb8835d458c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 0, should be 1: In scope SELECT sqrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sqrt();) 2025.03.31 19:06:16.431334 [ 3830 ] {b36653a3-1e78-4bef-ad9f-fb8835d458c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 0, should be 1: In scope SELECT sqrt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.444350 [ 3830 ] {459f4bb9-b7a1-4834-a530-cd07e48c96d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 0, should be 2: In scope SELECT startsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT startsWith();) 2025.03.31 19:06:16.445611 [ 3830 ] {459f4bb9-b7a1-4834-a530-cd07e48c96d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWith doesn't match: passed 0, should be 2: In scope SELECT startsWith(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.456063 [ 3830 ] {bd7ab3ea-c16e-4182-8281-54af278bca38} executeQuery: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT startsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT startsWithUTF8();) 2025.03.31 19:06:16.457029 [ 3830 ] {bd7ab3ea-c16e-4182-8281-54af278bca38} TCPHandler: Code: 42. DB::Exception: Number of arguments for function startsWithUTF8 doesn't match: passed 0, should be 2: In scope SELECT startsWithUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.467504 [ 3830 ] {d51e6c11-38da-4997-b257-810f63be4b4c} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stddevPop();) 2025.03.31 19:06:16.468466 [ 3830 ] {d51e6c11-38da-4997-b257-810f63be4b4c} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.569325 [ 3830 ] {add85ab6-fea1-402f-856d-70e95eb5d0b3} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stddevPopStable();) 2025.03.31 19:06:16.571208 [ 3830 ] {add85ab6-fea1-402f-856d-70e95eb5d0b3} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.584960 [ 3830 ] {55620d76-2526-407d-87cd-0cb2bceb6c97} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stddevSamp();) 2025.03.31 19:06:16.586738 [ 3830 ] {55620d76-2526-407d-87cd-0cb2bceb6c97} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.658751 [ 3830 ] {5e428a5a-20d7-4a79-aefa-4146ba43cdc5} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stddevSampStable();) 2025.03.31 19:06:16.660496 [ 3830 ] {5e428a5a-20d7-4a79-aefa-4146ba43cdc5} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.716737 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:16.762818 [ 3830 ] {ff28152e-3d5c-4448-b7cd-9b35928ae59f} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stem();) 2025.03.31 19:06:16.764425 [ 3830 ] {ff28152e-3d5c-4448-b7cd-9b35928ae59f} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:06:16.777455 [ 3830 ] {b37d3957-9841-4b66-83eb-4b2711a6ad22} executeQuery: Code: 35. DB::Exception: Aggregate function stochasticLinearRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stochasticLinearRegression();) 2025.03.31 19:06:16.779040 [ 3830 ] {b37d3957-9841-4b66-83eb-4b2711a6ad22} TCPHandler: Code: 35. DB::Exception: Aggregate function stochasticLinearRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:16.795055 [ 3830 ] {0dba5a51-f237-40c8-a79b-34ee3fff9779} executeQuery: Code: 35. DB::Exception: Aggregate function stochasticLogisticRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stochasticLogisticRegression();) 2025.03.31 19:06:16.796749 [ 3830 ] {0dba5a51-f237-40c8-a79b-34ee3fff9779} TCPHandler: Code: 35. DB::Exception: Aggregate function stochasticLogisticRegression requires at least two arguments: target and model's parameters. (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:16.810449 [ 3830 ] {c8a7663c-b32a-466d-a610-9309ee0419ca} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT str_to_date(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT str_to_date();) 2025.03.31 19:06:16.811950 [ 3830 ] {c8a7663c-b32a-466d-a610-9309ee0419ca} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'parseDateTimeOrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT str_to_date(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.827023 [ 3830 ] {8dfb90c3-7272-4df6-8410-8f9a63e41326} executeQuery: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT str_to_map(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT str_to_map();) 2025.03.31 19:06:16.828885 [ 3830 ] {8dfb90c3-7272-4df6-8410-8f9a63e41326} TCPHandler: Code: 42. DB::Exception: Function extractKeyValuePairs requires at least 1 argument and at most 4. 0 was provided: In scope SELECT str_to_map(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.843504 [ 3830 ] {957e868b-545d-495d-a9a7-a70492f8416d} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stringJaccardIndex();) 2025.03.31 19:06:16.845248 [ 3830 ] {957e868b-545d-495d-a9a7-a70492f8416d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndex doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.858490 [ 3830 ] {d1d2615c-5992-40bd-8727-02772a8d6589} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stringJaccardIndexUTF8();) 2025.03.31 19:06:16.859995 [ 3830 ] {d1d2615c-5992-40bd-8727-02772a8d6589} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringJaccardIndexUTF8 doesn't match: passed 0, should be 2: In scope SELECT stringJaccardIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.874840 [ 3830 ] {9c851a90-a1e3-428f-8e42-4d1463e714d2} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 0, should be 1: In scope SELECT stringToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT stringToH3();) 2025.03.31 19:06:16.876716 [ 3830 ] {9c851a90-a1e3-428f-8e42-4d1463e714d2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 0, should be 1: In scope SELECT stringToH3(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.962946 [ 3830 ] {dcc11c85-7854-4a26-9c7e-ec455d2762de} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT structureToCapnProtoSchema();) 2025.03.31 19:06:16.964330 [ 3830 ] {dcc11c85-7854-4a26-9c7e-ec455d2762de} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToCapnProtoSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToCapnProtoSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.979642 [ 3830 ] {18ce1244-cee6-4bd2-932c-abf3783494dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToProtobufSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT structureToProtobufSchema();) 2025.03.31 19:06:16.981177 [ 3830 ] {18ce1244-cee6-4bd2-932c-abf3783494dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function structureToProtobufSchema doesn't match: passed 0, expected 1 or 2: In scope SELECT structureToProtobufSchema(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:16.995461 [ 3830 ] {55e3f358-06b9-410c-992d-e0dba4e8be29} executeQuery: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT studentTTest();) 2025.03.31 19:06:16.997109 [ 3830 ] {55e3f358-06b9-410c-992d-e0dba4e8be29} TCPHandler: Code: 42. DB::Exception: Aggregate function studentTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.011605 [ 3830 ] {1e775b9f-1119-4b74-98a4-928bacf44d41} executeQuery: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 0, should be 3: In scope SELECT subBitmap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subBitmap();) 2025.03.31 19:06:17.013406 [ 3830 ] {1e775b9f-1119-4b74-98a4-928bacf44d41} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 0, should be 3: In scope SELECT subBitmap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.097269 [ 3830 ] {3cf77e65-51b0-427b-8a92-2c977b329984} executeQuery: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 0, should be 2: In scope SELECT subDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subDate();) 2025.03.31 19:06:17.098819 [ 3830 ] {3cf77e65-51b0-427b-8a92-2c977b329984} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subDate doesn't match: passed 0, should be 2: In scope SELECT subDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.113033 [ 3830 ] {bcfa292f-8846-4df2-91ad-7c189fa829a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT substr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT substr();) 2025.03.31 19:06:17.114885 [ 3830 ] {bcfa292f-8846-4df2-91ad-7c189fa829a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substring doesn't match: passed 0, should be 2 or 3: In scope SELECT substr(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.167431 [ 3830 ] {d89b0ca2-3597-49e4-b54b-c33ee4249cb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT substringIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT substringIndex();) 2025.03.31 19:06:17.168863 [ 3830 ] {d89b0ca2-3597-49e4-b54b-c33ee4249cb9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 0, should be 3: In scope SELECT substringIndex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.193078 [ 3830 ] {b76ffdd7-0dae-4020-92db-ec1a4362ea5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 0, should be 3: In scope SELECT substringIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT substringIndexUTF8();) 2025.03.31 19:06:17.194682 [ 3830 ] {b76ffdd7-0dae-4020-92db-ec1a4362ea5e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 0, should be 3: In scope SELECT substringIndexUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.217851 [ 3830 ] {6129fb72-db0a-42e3-a4fc-0caf97af2d41} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT substringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT substringUTF8();) 2025.03.31 19:06:17.219443 [ 3830 ] {6129fb72-db0a-42e3-a4fc-0caf97af2d41} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringUTF8 doesn't match: passed 0, should be 2 or 3: In scope SELECT substringUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.232642 [ 3830 ] {8906a3d1-933f-49ac-9f15-19d93a0cafc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractDays doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractDays();) 2025.03.31 19:06:17.234308 [ 3830 ] {8906a3d1-933f-49ac-9f15-19d93a0cafc2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractDays doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractDays(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.247631 [ 3830 ] {1649c29f-659e-4933-8a57-dfa48dd034f9} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractHours doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractHours();) 2025.03.31 19:06:17.249043 [ 3830 ] {1649c29f-659e-4933-8a57-dfa48dd034f9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractHours doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractHours(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.343874 [ 3830 ] {0463dec9-4ed9-4f0d-af9b-898238ee514d} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 0, should be 2: In scope SELECT subtractInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractInterval();) 2025.03.31 19:06:17.345589 [ 3830 ] {0463dec9-4ed9-4f0d-af9b-898238ee514d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractInterval doesn't match: passed 0, should be 2: In scope SELECT subtractInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.358783 [ 3830 ] {0ab5b2bc-d450-4228-bf65-29f60bf3f8e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractMicroseconds();) 2025.03.31 19:06:17.360279 [ 3830 ] {0ab5b2bc-d450-4228-bf65-29f60bf3f8e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMicroseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMicroseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.375130 [ 3830 ] {6d5fab05-485e-40a6-9d44-c6da3d1075df} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractMilliseconds();) 2025.03.31 19:06:17.376817 [ 3830 ] {6d5fab05-485e-40a6-9d44-c6da3d1075df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMilliseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMilliseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.392005 [ 3830 ] {d57ec252-4b83-4aae-8063-b02c5ddfa9bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractMinutes();) 2025.03.31 19:06:17.394016 [ 3830 ] {d57ec252-4b83-4aae-8063-b02c5ddfa9bf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMinutes doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.439937 [ 3830 ] {4f7d9b0c-7217-4fcb-a3bb-aafb1a103dfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractMonths();) 2025.03.31 19:06:17.441694 [ 3830 ] {4f7d9b0c-7217-4fcb-a3bb-aafb1a103dfd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractMonths doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractMonths(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.454729 [ 3830 ] {74835951-167f-4476-8ed0-3762fe232e56} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractNanoseconds();) 2025.03.31 19:06:17.456347 [ 3830 ] {74835951-167f-4476-8ed0-3762fe232e56} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractNanoseconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractNanoseconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.492962 [ 3830 ] {78163320-0e1b-4d2c-a55f-00731201fec6} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractQuarters();) 2025.03.31 19:06:17.494779 [ 3830 ] {78163320-0e1b-4d2c-a55f-00731201fec6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractQuarters doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractQuarters(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.507761 [ 3830 ] {5931ed6f-5170-4818-9b67-d82390c591cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractSeconds();) 2025.03.31 19:06:17.509172 [ 3830 ] {5931ed6f-5170-4818-9b67-d82390c591cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractSeconds doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractSeconds(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.522555 [ 3830 ] {b94be767-209f-4a38-b8cd-2f96d849bdd5} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT subtractTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractTupleOfIntervals();) 2025.03.31 19:06:17.524423 [ 3830 ] {b94be767-209f-4a38-b8cd-2f96d849bdd5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractTupleOfIntervals doesn't match: passed 0, should be 2: In scope SELECT subtractTupleOfIntervals(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.537593 [ 3830 ] {c7f638a0-45b5-48a8-8ee6-c475633afbc4} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractWeeks();) 2025.03.31 19:06:17.539731 [ 3830 ] {c7f638a0-45b5-48a8-8ee6-c475633afbc4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractWeeks doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractWeeks(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.555168 [ 3830 ] {97d578ad-6d18-4d94-9d97-08fa011c15fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function subtractYears doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT subtractYears();) 2025.03.31 19:06:17.558133 [ 3830 ] {97d578ad-6d18-4d94-9d97-08fa011c15fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subtractYears doesn't match: passed 0, should be 2 or 3: In scope SELECT subtractYears(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.571429 [ 3830 ] {157afdc3-4af7-45a5-b194-773ec514c1c3} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sum();) 2025.03.31 19:06:17.573028 [ 3830 ] {157afdc3-4af7-45a5-b194-773ec514c1c3} TCPHandler: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.587561 [ 3830 ] {2a6950e4-078a-4ed0-9edc-ebb0319493c6} executeQuery: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumCount();) 2025.03.31 19:06:17.589331 [ 3830 ] {2a6950e4-078a-4ed0-9edc-ebb0319493c6} TCPHandler: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.666774 [ 3830 ] {a4768cbe-9da4-41e4-94d7-235ae099db17} executeQuery: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumKahan();) 2025.03.31 19:06:17.670155 [ 3830 ] {a4768cbe-9da4-41e4-94d7-235ae099db17} TCPHandler: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.683492 [ 3830 ] {06131caf-34fc-4e0b-b34a-fa6f1e63c6dd} executeQuery: Code: 42. DB::Exception: Aggregate function sumMapFiltered requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumMapFiltered();) 2025.03.31 19:06:17.685094 [ 3830 ] {06131caf-34fc-4e0b-b34a-fa6f1e63c6dd} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMapFiltered requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.700662 [ 3830 ] {59af223a-9807-4a79-ac23-1051119628b2} executeQuery: Code: 42. DB::Exception: Aggregate function sumMapFilteredWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumMapFilteredWithOverflow();) 2025.03.31 19:06:17.702763 [ 3830 ] {59af223a-9807-4a79-ac23-1051119628b2} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMapFilteredWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.716348 [ 3830 ] {4c0af5a3-54f0-43e6-913d-c8b80168434d} executeQuery: Code: 42. DB::Exception: Aggregate function sumMapWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumMapWithOverflow();) 2025.03.31 19:06:17.718514 [ 3830 ] {4c0af5a3-54f0-43e6-913d-c8b80168434d} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMapWithOverflow requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.733200 [ 3830 ] {41625da1-bc50-42de-8100-6f29ce77d973} executeQuery: Code: 42. DB::Exception: Aggregate function sumMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumMappedArrays();) 2025.03.31 19:06:17.735877 [ 3830 ] {41625da1-bc50-42de-8100-6f29ce77d973} TCPHandler: Code: 42. DB::Exception: Aggregate function sumMappedArrays requires at least two arguments of Array type or one argument of tuple of two arrays. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.748996 [ 3830 ] {71ebb4e0-b8a6-432d-becf-cb9d4b698908} executeQuery: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT sumWithOverflow();) 2025.03.31 19:06:17.817290 [ 3830 ] {71ebb4e0-b8a6-432d-becf-cb9d4b698908} TCPHandler: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.881326 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:17.886352 [ 3830 ] {f56f89c9-abb4-4f05-91f7-942756f11736} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT svg();) 2025.03.31 19:06:17.887847 [ 3830 ] {f56f89c9-abb4-4f05-91f7-942756f11736} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments: expected 1 or 2 arguments: In scope SELECT svg(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.900628 [ 3830 ] {06b933d3-50c4-4915-b3b1-622b36fb3128} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT synonyms();) 2025.03.31 19:06:17.902224 [ 3830 ] {06b933d3-50c4-4915-b3b1-622b36fb3128} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.03.31 19:06:17.916626 [ 3830 ] {1a4c3b6a-d53c-466d-9368-3de2efdc9256} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 0, should be 1: In scope SELECT tan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tan();) 2025.03.31 19:06:17.918242 [ 3830 ] {1a4c3b6a-d53c-466d-9368-3de2efdc9256} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 0, should be 1: In scope SELECT tan(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:17.932380 [ 3830 ] {5e23fc80-cd34-48f7-82b9-9afe801d82df} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 0, should be 1: In scope SELECT tanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tanh();) 2025.03.31 19:06:17.934117 [ 3830 ] {5e23fc80-cd34-48f7-82b9-9afe801d82df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 0, should be 1: In scope SELECT tanh(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.023812 [ 3830 ] {5091f4be-8cf2-4adc-ad96-65d2198f9479} executeQuery: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 0, should be 2: In scope SELECT test_function(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT test_function();) 2025.03.31 19:06:18.025363 [ 3830 ] {5091f4be-8cf2-4adc-ad96-65d2198f9479} TCPHandler: Code: 42. DB::Exception: Number of arguments for function test_function doesn't match: passed 0, should be 2: In scope SELECT test_function(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.041994 [ 3830 ] {5bcbf247-1aeb-44dd-acf7-e1fcca2e5ce7} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 0, should be 1: In scope SELECT tgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tgamma();) 2025.03.31 19:06:18.043723 [ 3830 ] {5bcbf247-1aeb-44dd-acf7-e1fcca2e5ce7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 0, should be 1: In scope SELECT tgamma(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.057950 [ 3830 ] {f2ebdbd2-7e48-4050-a2b2-af0c1505ac68} executeQuery: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT theilsU();) 2025.03.31 19:06:18.059426 [ 3830 ] {f2ebdbd2-7e48-4050-a2b2-af0c1505ac68} TCPHandler: Code: 42. DB::Exception: Aggregate function theilsU requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.116093 [ 3830 ] {9c0d4cd4-6871-46b3-a70e-7b662f3acd34} executeQuery: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 0, should be 1 or 2: In scope SELECT throwIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT throwIf();) 2025.03.31 19:06:18.117639 [ 3830 ] {9c0d4cd4-6871-46b3-a70e-7b662f3acd34} TCPHandler: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 0, should be 1 or 2: In scope SELECT throwIf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.287927 [ 3830 ] {b8b9e31d-f7ab-4632-bdf5-397163f113a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 0, should be 2: In scope SELECT timeDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timeDiff();) 2025.03.31 19:06:18.289980 [ 3830 ] {b8b9e31d-f7ab-4632-bdf5-397163f113a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeDiff doesn't match: passed 0, should be 2: In scope SELECT timeDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.305048 [ 3830 ] {b4e7a835-5936-4a78-b1a6-8729313e161d} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 0, should be 1 or 2: In scope SELECT timeSlot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timeSlot();) 2025.03.31 19:06:18.306865 [ 3830 ] {b4e7a835-5936-4a78-b1a6-8729313e161d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlot doesn't match: passed 0, should be 1 or 2: In scope SELECT timeSlot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.322043 [ 3830 ] {61d30abd-f707-486c-8084-ec23b24aa545} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 0, should be 2 or 3: In scope SELECT timeSlots(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timeSlots();) 2025.03.31 19:06:18.323930 [ 3830 ] {61d30abd-f707-486c-8084-ec23b24aa545} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 0, should be 2 or 3: In scope SELECT timeSlots(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.366487 [ 3830 ] {dfc1dd8b-02b9-4c3b-8daf-4183ed95118f} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timeZoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timeZoneOf();) 2025.03.31 19:06:18.368338 [ 3830 ] {dfc1dd8b-02b9-4c3b-8daf-4183ed95118f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timeZoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.383963 [ 3830 ] {dfd605b4-f25c-41ca-8304-af077984e443} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timeZoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timeZoneOffset();) 2025.03.31 19:06:18.385968 [ 3830 ] {dfd605b4-f25c-41ca-8304-af077984e443} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timeZoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.400865 [ 3830 ] {0364d8e9-ac9f-4705-8c90-29b1b3c89fba} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timestamp();) 2025.03.31 19:06:18.402796 [ 3830 ] {0364d8e9-ac9f-4705-8c90-29b1b3c89fba} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'timestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.417378 [ 3830 ] {94c07044-136c-4dda-8875-ef056cbe9753} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timestampDiff();) 2025.03.31 19:06:18.419185 [ 3830 ] {94c07044-136c-4dda-8875-ef056cbe9753} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.459026 [ 3830 ] {c775ee78-55a4-462e-8f0e-74fcb22a3a76} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timestamp_diff();) 2025.03.31 19:06:18.460627 [ 3830 ] {c775ee78-55a4-462e-8f0e-74fcb22a3a76} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT dateDiff(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.501436 [ 3830 ] {50a3a973-4ca4-4ae6-b612-accaa574fabb} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timezoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timezoneOf();) 2025.03.31 19:06:18.503288 [ 3830 ] {50a3a973-4ca4-4ae6-b612-accaa574fabb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 0, should be 1: In scope SELECT timezoneOf(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.518060 [ 3830 ] {72c4980a-2246-4507-92a0-5914c707c5da} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timezoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT timezoneOffset();) 2025.03.31 19:06:18.519714 [ 3830 ] {72c4980a-2246-4507-92a0-5914c707c5da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOffset doesn't match: passed 0, should be 1 or 2: In scope SELECT timezoneOffset(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.543331 [ 3830 ] {081e97fd-979f-4878-8fad-51ae5aed8573} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 0, should be 1: In scope SELECT toBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toBool();) 2025.03.31 19:06:18.545008 [ 3830 ] {081e97fd-979f-4878-8fad-51ae5aed8573} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 0, should be 1: In scope SELECT toBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.626801 [ 3830 ] {383d28e8-d5da-40ba-beed-7b93564b33d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 0, should be 1: In scope SELECT toColumnTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toColumnTypeName();) 2025.03.31 19:06:18.628284 [ 3830 ] {383d28e8-d5da-40ba-beed-7b93564b33d6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 0, should be 1: In scope SELECT toColumnTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.642642 [ 3830 ] {e55a82a5-2a2d-41aa-9b47-3d296dc3bbb2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDate();) 2025.03.31 19:06:18.644411 [ 3830 ] {e55a82a5-2a2d-41aa-9b47-3d296dc3bbb2} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.658506 [ 3830 ] {9c0d230e-31dc-4b85-bcd6-d21233474f2f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDate32();) 2025.03.31 19:06:18.660423 [ 3830 ] {9c0d230e-31dc-4b85-bcd6-d21233474f2f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.673581 [ 3830 ] {8c0e4d3e-3383-4d25-a918-5f679325e90a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDate32OrDefault();) 2025.03.31 19:06:18.675293 [ 3830 ] {8c0e4d3e-3383-4d25-a918-5f679325e90a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDate32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDate32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.687718 [ 3830 ] {794095b6-d173-4417-924f-0d3b33270281} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDate32OrNull();) 2025.03.31 19:06:18.689158 [ 3830 ] {794095b6-d173-4417-924f-0d3b33270281} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.703177 [ 3830 ] {3b74f3cd-1578-4ec2-a68e-c5c2b224d9a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDate32OrZero();) 2025.03.31 19:06:18.704886 [ 3830 ] {3b74f3cd-1578-4ec2-a68e-c5c2b224d9a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDate32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDate32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.731013 [ 3830 ] {cd80a138-5e57-4dff-ac2e-952d7324fdcf} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateOrDefault();) 2025.03.31 19:06:18.732886 [ 3830 ] {cd80a138-5e57-4dff-ac2e-952d7324fdcf} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.749552 [ 3830 ] {97bb3818-e337-4076-b793-7c3f6df5975e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateOrNull();) 2025.03.31 19:06:18.751649 [ 3830 ] {97bb3818-e337-4076-b793-7c3f6df5975e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.765156 [ 3830 ] {1228f940-e413-4aa4-ab22-3f43fa1ed0ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateOrZero();) 2025.03.31 19:06:18.766933 [ 3830 ] {1228f940-e413-4aa4-ab22-3f43fa1ed0ff} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.781269 [ 3830 ] {0ad9f3fc-91c0-4386-a61e-8f84a5077c16} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime();) 2025.03.31 19:06:18.783095 [ 3830 ] {0ad9f3fc-91c0-4386-a61e-8f84a5077c16} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.796861 [ 3830 ] {f112e4f2-37e4-4973-928a-ef6bb6fd0b4f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime32();) 2025.03.31 19:06:18.798570 [ 3830 ] {f112e4f2-37e4-4973-928a-ef6bb6fd0b4f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime32'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toDateTime32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.814863 [ 3830 ] {1635f457-d1ea-4c17-b280-7ed15edc9375} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime64();) 2025.03.31 19:06:18.816805 [ 3830 ] {1635f457-d1ea-4c17-b280-7ed15edc9375} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDateTime64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.911928 [ 3830 ] {9fb60965-98f8-44f2-81a3-e7c8460e68bc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrDefault'. Expected 2 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime64OrDefault();) 2025.03.31 19:06:18.913347 [ 3830 ] {9fb60965-98f8-44f2-81a3-e7c8460e68bc} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrDefault'. Expected 2 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.929039 [ 3830 ] {5b5b34f2-f536-427e-9084-629df36be3d1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime64OrNull();) 2025.03.31 19:06:18.931055 [ 3830 ] {5b5b34f2-f536-427e-9084-629df36be3d1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrNull'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.944729 [ 3830 ] {155dd3df-5cb5-45b5-83ab-ca17482ce3e6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTime64OrZero();) 2025.03.31 19:06:18.956954 [ 3830 ] {155dd3df-5cb5-45b5-83ab-ca17482ce3e6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTime64OrZero'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTime64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.971072 [ 3830 ] {a4f764d5-ecb6-4995-a6dc-e38e4df1206d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTimeOrDefault'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTimeOrDefault();) 2025.03.31 19:06:18.972725 [ 3830 ] {a4f764d5-ecb6-4995-a6dc-e38e4df1206d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDateTimeOrDefault'. Expected 1 mandatory argument and 2 optional arguments, got 0 arguments: In scope SELECT toDateTimeOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:18.986873 [ 3830 ] {983f4974-cbb1-407c-8fa1-8332801cb8ed} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTimeOrNull();) 2025.03.31 19:06:18.988673 [ 3830 ] {983f4974-cbb1-407c-8fa1-8332801cb8ed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.002499 [ 3830 ] {0c5b31f5-054b-449a-a348-aef341d4de79} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDateTimeOrZero();) 2025.03.31 19:06:19.004223 [ 3830 ] {0c5b31f5-054b-449a-a348-aef341d4de79} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDateTimeOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDateTimeOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.018961 [ 3830 ] {bcbea1b5-29ee-409a-92f4-113a23a9aa6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDayOfMonth();) 2025.03.31 19:06:19.020626 [ 3830 ] {bcbea1b5-29ee-409a-92f4-113a23a9aa6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.032726 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:19.034852 [ 3830 ] {484f62f7-84d6-470e-a683-e612d2b47131} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDayOfWeek();) 2025.03.31 19:06:19.036565 [ 3830 ] {484f62f7-84d6-470e-a683-e612d2b47131} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.051017 [ 3830 ] {ef7fb98f-3bc6-4860-bb5e-c2e31e5df030} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDayOfYear();) 2025.03.31 19:06:19.052472 [ 3830 ] {ef7fb98f-3bc6-4860-bb5e-c2e31e5df030} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDayOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toDayOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.113699 [ 3830 ] {35714e7c-2be8-4df2-b6d0-498540700f4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT toDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDaysSinceYearZero();) 2025.03.31 19:06:19.115177 [ 3830 ] {35714e7c-2be8-4df2-b6d0-498540700f4c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT toDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.127778 [ 3830 ] {5feb171b-7c10-4a00-8db2-c90e01361324} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal128();) 2025.03.31 19:06:19.129286 [ 3830 ] {5feb171b-7c10-4a00-8db2-c90e01361324} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.221187 [ 3830 ] {c8ea9a02-f058-4b4a-902b-f5219bc6577e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal128OrDefault();) 2025.03.31 19:06:19.222852 [ 3830 ] {c8ea9a02-f058-4b4a-902b-f5219bc6577e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal128OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.236502 [ 3830 ] {22cfda76-a3ec-4836-8ab7-8c1c8cdaf346} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal128OrNull();) 2025.03.31 19:06:19.238078 [ 3830 ] {22cfda76-a3ec-4836-8ab7-8c1c8cdaf346} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.252370 [ 3830 ] {33623c4e-6e51-4190-98de-a79c514ac07e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal128OrZero();) 2025.03.31 19:06:19.254035 [ 3830 ] {33623c4e-6e51-4190-98de-a79c514ac07e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.266861 [ 3830 ] {bc2ea11d-a4ec-4cfb-9a96-4e24b91a6fab} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal256();) 2025.03.31 19:06:19.268326 [ 3830 ] {bc2ea11d-a4ec-4cfb-9a96-4e24b91a6fab} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.280697 [ 3830 ] {aad5feeb-ae0c-4e07-b1d6-53dcbdd1d512} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal256OrDefault();) 2025.03.31 19:06:19.282449 [ 3830 ] {aad5feeb-ae0c-4e07-b1d6-53dcbdd1d512} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal256OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.296147 [ 3830 ] {45e57e01-27d5-4204-bb4e-c82624da18e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal256OrNull();) 2025.03.31 19:06:19.298965 [ 3830 ] {45e57e01-27d5-4204-bb4e-c82624da18e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.311082 [ 3830 ] {827dd0c0-ba6f-4b92-a561-3e653e657fea} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal256OrZero();) 2025.03.31 19:06:19.312587 [ 3830 ] {827dd0c0-ba6f-4b92-a561-3e653e657fea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.325649 [ 3830 ] {937ca048-1811-4b21-b5d8-c0c0ab9af0fd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal32();) 2025.03.31 19:06:19.327440 [ 3830 ] {937ca048-1811-4b21-b5d8-c0c0ab9af0fd} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.342069 [ 3830 ] {16c68bef-09be-41b2-b793-37203765f884} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal32OrDefault();) 2025.03.31 19:06:19.343615 [ 3830 ] {16c68bef-09be-41b2-b793-37203765f884} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal32OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.379114 [ 3830 ] {ce46d4a3-be85-4dae-95d1-baa20b54dc31} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal32OrNull();) 2025.03.31 19:06:19.380594 [ 3830 ] {ce46d4a3-be85-4dae-95d1-baa20b54dc31} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.393565 [ 3830 ] {6196db87-06cd-4cb5-9140-fa495936ffd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal32OrZero();) 2025.03.31 19:06:19.395369 [ 3830 ] {6196db87-06cd-4cb5-9140-fa495936ffd1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.407571 [ 3830 ] {01275721-95eb-404d-ad94-e5db25bbba2d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal64();) 2025.03.31 19:06:19.408933 [ 3830 ] {01275721-95eb-404d-ad94-e5db25bbba2d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64'. Expected 2 arguments, got 0 arguments: In scope SELECT toDecimal64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.471369 [ 3830 ] {f27116da-0a74-4c3a-b160-b7a9b193bfd4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal64OrDefault();) 2025.03.31 19:06:19.473337 [ 3830 ] {f27116da-0a74-4c3a-b160-b7a9b193bfd4} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toDecimal64OrDefault'. Expected 2 mandatory arguments and 1 optional argument, got 0 arguments: In scope SELECT toDecimal64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.487829 [ 3830 ] {b0e429bd-40a6-42f5-978e-8b4d32abac19} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal64OrNull();) 2025.03.31 19:06:19.489986 [ 3830 ] {b0e429bd-40a6-42f5-978e-8b4d32abac19} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.504181 [ 3830 ] {2f689c2d-5b32-4089-95b8-b187f46db02e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimal64OrZero();) 2025.03.31 19:06:19.506053 [ 3830 ] {2f689c2d-5b32-4089-95b8-b187f46db02e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimal64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toDecimal64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.520634 [ 3830 ] {d4761cda-a040-4ed7-9b98-9f7282544da5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 0, should be 2: In scope SELECT toDecimalString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toDecimalString();) 2025.03.31 19:06:19.522627 [ 3830 ] {d4761cda-a040-4ed7-9b98-9f7282544da5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDecimalString doesn't match: passed 0, should be 2: In scope SELECT toDecimalString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.557670 [ 3830 ] {28706b27-8a04-4471-aebb-8ba7b05fccbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 0, should be 2: In scope SELECT toFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFixedString();) 2025.03.31 19:06:19.560001 [ 3830 ] {28706b27-8a04-4471-aebb-8ba7b05fccbe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFixedString doesn't match: passed 0, should be 2: In scope SELECT toFixedString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.573679 [ 3830 ] {0a694d4d-6932-4d79-8d25-55a10b89a2e6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat32();) 2025.03.31 19:06:19.575570 [ 3830 ] {0a694d4d-6932-4d79-8d25-55a10b89a2e6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.588596 [ 3830 ] {0fdeed6d-39db-441f-bd0f-8ed85e4e63a8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat32OrDefault();) 2025.03.31 19:06:19.590253 [ 3830 ] {0fdeed6d-39db-441f-bd0f-8ed85e4e63a8} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.603247 [ 3830 ] {a1c492ef-549f-40ed-bd19-bd382b6aed84} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat32OrNull();) 2025.03.31 19:06:19.604716 [ 3830 ] {a1c492ef-549f-40ed-bd19-bd382b6aed84} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.617928 [ 3830 ] {95d3e028-9d03-4f21-b1bb-aa922e77a65a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat32OrZero();) 2025.03.31 19:06:19.619403 [ 3830 ] {95d3e028-9d03-4f21-b1bb-aa922e77a65a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.633059 [ 3830 ] {1fc732a1-8c59-4ee1-902a-d05d13563c12} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat64();) 2025.03.31 19:06:19.634755 [ 3830 ] {1fc732a1-8c59-4ee1-902a-d05d13563c12} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 0 arguments: In scope SELECT toFloat64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.650123 [ 3830 ] {62beb122-e92a-4536-8760-5a8509062e0b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat64OrDefault();) 2025.03.31 19:06:19.651867 [ 3830 ] {62beb122-e92a-4536-8760-5a8509062e0b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toFloat64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.667065 [ 3830 ] {eeb49a8e-3fd1-452d-b03f-35b6a0621d50} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat64OrNull();) 2025.03.31 19:06:19.668833 [ 3830 ] {eeb49a8e-3fd1-452d-b03f-35b6a0621d50} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.681882 [ 3830 ] {4847598f-90dd-49b6-a3fc-24bab6752de6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toFloat64OrZero();) 2025.03.31 19:06:19.683310 [ 3830 ] {4847598f-90dd-49b6-a3fc-24bab6752de6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toFloat64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toFloat64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.780588 [ 3830 ] {a819d890-56ab-499e-95df-6c047db5861f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toHour();) 2025.03.31 19:06:19.782330 [ 3830 ] {a819d890-56ab-499e-95df-6c047db5861f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.795640 [ 3830 ] {e34e4e6a-fa09-4c3a-8772-023e66306c5f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv4();) 2025.03.31 19:06:19.798565 [ 3830 ] {e34e4e6a-fa09-4c3a-8772-023e66306c5f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv4(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.810845 [ 3830 ] {f8503d85-7194-4178-8efb-09c913c6d24a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv4OrDefault();) 2025.03.31 19:06:19.812292 [ 3830 ] {f8503d85-7194-4178-8efb-09c913c6d24a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv4OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.825133 [ 3830 ] {3f09d939-1974-4498-84bc-f060829649c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv4OrNull();) 2025.03.31 19:06:19.828106 [ 3830 ] {3f09d939-1974-4498-84bc-f060829649c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.840463 [ 3830 ] {7379077a-92d2-49d7-b926-6de85f32a53a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv4OrZero();) 2025.03.31 19:06:19.842069 [ 3830 ] {7379077a-92d2-49d7-b926-6de85f32a53a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv4OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv4OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.856204 [ 3830 ] {8cc75e66-4f4d-4632-9ed0-e83a66a149dd} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv6();) 2025.03.31 19:06:19.857858 [ 3830 ] {8cc75e66-4f4d-4632-9ed0-e83a66a149dd} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 0 arguments: In scope SELECT toIPv6(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.870454 [ 3830 ] {eeff2d33-c2b6-4129-8f7f-924926627c6c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv6OrDefault();) 2025.03.31 19:06:19.871932 [ 3830 ] {eeff2d33-c2b6-4129-8f7f-924926627c6c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toIPv6OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.884327 [ 3830 ] {9bfb0d76-e97f-4626-adc2-0f349471c53a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv6OrNull();) 2025.03.31 19:06:19.885921 [ 3830 ] {9bfb0d76-e97f-4626-adc2-0f349471c53a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:19.990891 [ 3830 ] {006ade49-6c5f-4af6-8bf6-80002fc86d26} executeQuery: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIPv6OrZero();) 2025.03.31 19:06:20.002334 [ 3830 ] {006ade49-6c5f-4af6-8bf6-80002fc86d26} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toIPv6OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toIPv6OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.015808 [ 3830 ] {d7e79f2f-0fa7-4b20-b6c2-ddad686ed429} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toISOWeek();) 2025.03.31 19:06:20.017613 [ 3830 ] {d7e79f2f-0fa7-4b20-b6c2-ddad686ed429} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOWeek doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.103764 [ 3830 ] {d835043e-f59e-4600-9ba0-46898f9cbdb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toISOYear();) 2025.03.31 19:06:20.105379 [ 3830 ] {d835043e-f59e-4600-9ba0-46898f9cbdb9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.119196 [ 3830 ] {0340e9f1-1e34-4225-9be8-dec0146fda4d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt128();) 2025.03.31 19:06:20.120916 [ 3830 ] {0340e9f1-1e34-4225-9be8-dec0146fda4d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.127637 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:20.133214 [ 3830 ] {a5504ae7-a519-4488-8b59-8aceed0e29d0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt128OrDefault();) 2025.03.31 19:06:20.134699 [ 3830 ] {a5504ae7-a519-4488-8b59-8aceed0e29d0} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.225043 [ 3830 ] {a5232c3a-4ae1-494b-a456-d4609b968309} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt128OrNull();) 2025.03.31 19:06:20.226722 [ 3830 ] {a5232c3a-4ae1-494b-a456-d4609b968309} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.240710 [ 3830 ] {a25c290d-fa02-49cd-8fc2-a0ed792382d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt128OrZero();) 2025.03.31 19:06:20.242447 [ 3830 ] {a25c290d-fa02-49cd-8fc2-a0ed792382d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.255785 [ 3830 ] {6d303889-6bc7-4ea3-b239-48f99460fb75} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt16();) 2025.03.31 19:06:20.257243 [ 3830 ] {6d303889-6bc7-4ea3-b239-48f99460fb75} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.271829 [ 3830 ] {da15108b-797e-40e6-a559-2bef8198ba0b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt16OrDefault();) 2025.03.31 19:06:20.273633 [ 3830 ] {da15108b-797e-40e6-a559-2bef8198ba0b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.286843 [ 3830 ] {fc880237-d7ba-4105-ab69-08a95907ed43} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt16OrNull();) 2025.03.31 19:06:20.288286 [ 3830 ] {fc880237-d7ba-4105-ab69-08a95907ed43} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.300439 [ 3830 ] {83769733-9cd5-4952-b582-a484343b0f50} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt16OrZero();) 2025.03.31 19:06:20.301886 [ 3830 ] {83769733-9cd5-4952-b582-a484343b0f50} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.390023 [ 3830 ] {f2b3eeb4-b862-4e34-a31a-0b4ff33a1577} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt256();) 2025.03.31 19:06:20.391501 [ 3830 ] {f2b3eeb4-b862-4e34-a31a-0b4ff33a1577} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.405397 [ 3830 ] {6882717a-8b83-4187-91b2-e639fb894b0a} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt256OrDefault();) 2025.03.31 19:06:20.406902 [ 3830 ] {6882717a-8b83-4187-91b2-e639fb894b0a} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.419389 [ 3830 ] {f269b01a-cda8-495f-82b2-3cd8c1fcaa24} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt256OrNull();) 2025.03.31 19:06:20.420849 [ 3830 ] {f269b01a-cda8-495f-82b2-3cd8c1fcaa24} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.433847 [ 3830 ] {a22b7518-c109-49bb-95c5-7a7a4bb8bc94} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt256OrZero();) 2025.03.31 19:06:20.435249 [ 3830 ] {a22b7518-c109-49bb-95c5-7a7a4bb8bc94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.448610 [ 3830 ] {e3e41085-db70-4adf-93a4-5fce4f2ae194} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt32();) 2025.03.31 19:06:20.450310 [ 3830 ] {e3e41085-db70-4adf-93a4-5fce4f2ae194} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.480524 [ 3830 ] {f1c798a5-559f-4913-b77f-68910e09ee67} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt32OrDefault();) 2025.03.31 19:06:20.482017 [ 3830 ] {f1c798a5-559f-4913-b77f-68910e09ee67} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.495761 [ 3830 ] {8d1117a6-4361-4158-9942-58a2999367a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt32OrNull();) 2025.03.31 19:06:20.497225 [ 3830 ] {8d1117a6-4361-4158-9942-58a2999367a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.509698 [ 3830 ] {edbe6080-9606-492e-bb62-6acc732ca96e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt32OrZero();) 2025.03.31 19:06:20.511516 [ 3830 ] {edbe6080-9606-492e-bb62-6acc732ca96e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.523831 [ 3830 ] {3071bf9f-6162-4302-8a9f-96408aea9d6c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt64();) 2025.03.31 19:06:20.525309 [ 3830 ] {3071bf9f-6162-4302-8a9f-96408aea9d6c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.537390 [ 3830 ] {68163c57-faef-4f79-aaed-db4ccaf4aa9d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt64OrDefault();) 2025.03.31 19:06:20.539036 [ 3830 ] {68163c57-faef-4f79-aaed-db4ccaf4aa9d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.553382 [ 3830 ] {4093c1b2-419e-4e73-9df8-62c0cc4ae52c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt64OrNull();) 2025.03.31 19:06:20.555359 [ 3830 ] {4093c1b2-419e-4e73-9df8-62c0cc4ae52c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.569221 [ 3830 ] {0199f586-068a-42ed-ad53-6d182ca45d67} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt64OrZero();) 2025.03.31 19:06:20.572830 [ 3830 ] {0199f586-068a-42ed-ad53-6d182ca45d67} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.586853 [ 3830 ] {19a927bd-b700-408d-84e9-00e3149e2d6e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt8();) 2025.03.31 19:06:20.588516 [ 3830 ] {19a927bd-b700-408d-84e9-00e3149e2d6e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.601878 [ 3830 ] {16c15ddc-ecbb-4758-91db-ea13458a1881} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt8OrDefault();) 2025.03.31 19:06:20.603508 [ 3830 ] {16c15ddc-ecbb-4758-91db-ea13458a1881} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.654555 [ 3830 ] {7cb85416-e310-4475-aa86-36233a01fc0f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt8OrNull();) 2025.03.31 19:06:20.656021 [ 3830 ] {7cb85416-e310-4475-aa86-36233a01fc0f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.727449 [ 3830 ] {00290fbe-82f5-4ac6-8018-67b5ae4b572b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toInt8OrZero();) 2025.03.31 19:06:20.728975 [ 3830 ] {00290fbe-82f5-4ac6-8018-67b5ae4b572b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.742608 [ 3830 ] {306915f4-aa90-4449-b3e0-a4a04a614ce0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalDay();) 2025.03.31 19:06:20.744025 [ 3830 ] {306915f4-aa90-4449-b3e0-a4a04a614ce0} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.758336 [ 3830 ] {61101583-5557-4e6d-827a-fd9420e12d59} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalHour();) 2025.03.31 19:06:20.760060 [ 3830 ] {61101583-5557-4e6d-827a-fd9420e12d59} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.774797 [ 3830 ] {21a28893-6d84-4143-a556-ca9afa7725ce} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalMicrosecond();) 2025.03.31 19:06:20.776403 [ 3830 ] {21a28893-6d84-4143-a556-ca9afa7725ce} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.857985 [ 3830 ] {a11d0b6d-4dad-4aed-a517-6dd8dd59d112} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalMillisecond();) 2025.03.31 19:06:20.859774 [ 3830 ] {a11d0b6d-4dad-4aed-a517-6dd8dd59d112} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.874831 [ 3830 ] {feda7c51-10b9-4e08-8637-12e9c72c2402} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalMinute();) 2025.03.31 19:06:20.876498 [ 3830 ] {feda7c51-10b9-4e08-8637-12e9c72c2402} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:20.981623 [ 3830 ] {e5753609-cede-42e4-be8c-62f64a9d9a63} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalMonth();) 2025.03.31 19:06:20.983608 [ 3830 ] {e5753609-cede-42e4-be8c-62f64a9d9a63} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.044586 [ 3830 ] {55085093-babe-4d01-bf48-03119e220234} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalNanosecond();) 2025.03.31 19:06:21.046338 [ 3830 ] {55085093-babe-4d01-bf48-03119e220234} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.060056 [ 3830 ] {845acc42-5117-47d6-9b0c-809a421bad71} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalQuarter();) 2025.03.31 19:06:21.061889 [ 3830 ] {845acc42-5117-47d6-9b0c-809a421bad71} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.075348 [ 3830 ] {0dde36b6-9d76-4443-9e5c-ec208f587b5b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalSecond();) 2025.03.31 19:06:21.076939 [ 3830 ] {0dde36b6-9d76-4443-9e5c-ec208f587b5b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.091152 [ 3830 ] {a726f70d-ffe8-44e8-b69c-b506d688b72d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalWeek();) 2025.03.31 19:06:21.094616 [ 3830 ] {a726f70d-ffe8-44e8-b69c-b506d688b72d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.107706 [ 3830 ] {8f6ce3e6-31b2-4784-83af-311e5e6ce73b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toIntervalYear();) 2025.03.31 19:06:21.109441 [ 3830 ] {8f6ce3e6-31b2-4784-83af-311e5e6ce73b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 0 arguments: In scope SELECT toIntervalYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.122863 [ 3830 ] {7077a101-3a62-43c4-b2c4-8cedddd33188} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 0, should be 1: In scope SELECT toJSONString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toJSONString();) 2025.03.31 19:06:21.124385 [ 3830 ] {7077a101-3a62-43c4-b2c4-8cedddd33188} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 0, should be 1: In scope SELECT toJSONString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.137782 [ 3830 ] {ff29a331-4d23-40ba-acca-735c3c22d4cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toLastDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toLastDayOfMonth();) 2025.03.31 19:06:21.139310 [ 3830 ] {ff29a331-4d23-40ba-acca-735c3c22d4cf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toLastDayOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.181052 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:21.229556 [ 3830 ] {22bc22eb-1bc2-4cae-b953-83819620d036} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLastDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toLastDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toLastDayOfWeek();) 2025.03.31 19:06:21.232839 [ 3830 ] {22bc22eb-1bc2-4cae-b953-83819620d036} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLastDayOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toLastDayOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.244180 [ 3830 ] {ce6de542-f9c6-4e5b-a458-074b78fcc5a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 0, should be 1: In scope SELECT toLowCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toLowCardinality();) 2025.03.31 19:06:21.245562 [ 3830 ] {ce6de542-f9c6-4e5b-a458-074b78fcc5a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 0, should be 1: In scope SELECT toLowCardinality(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.258135 [ 3830 ] {199e18d4-53a2-4aff-b299-fdc80f4b178e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toMillisecond();) 2025.03.31 19:06:21.259652 [ 3830 ] {199e18d4-53a2-4aff-b299-fdc80f4b178e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.274772 [ 3830 ] {8f0290ef-2275-4091-a30e-7c78801600fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toMinute();) 2025.03.31 19:06:21.276378 [ 3830 ] {8f0290ef-2275-4091-a30e-7c78801600fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.289637 [ 3830 ] {b924df63-590f-4acb-b493-e6caf589e7d8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toModifiedJulianDay();) 2025.03.31 19:06:21.291295 [ 3830 ] {b924df63-590f-4acb-b493-e6caf589e7d8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.305633 [ 3830 ] {1ae78412-62c6-4079-a588-37df5e59f1ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toModifiedJulianDayOrNull();) 2025.03.31 19:06:21.307447 [ 3830 ] {1ae78412-62c6-4079-a588-37df5e59f1ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 0, should be 1: In scope SELECT toModifiedJulianDayOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.320058 [ 3830 ] {e88b6f00-40ac-4625-b5c5-cf053f508f08} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonday(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toMonday();) 2025.03.31 19:06:21.321491 [ 3830 ] {e88b6f00-40ac-4625-b5c5-cf053f508f08} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonday doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonday(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.333928 [ 3830 ] {aca07bcd-b86f-40e0-9d88-5c68cbb0e226} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toMonth();) 2025.03.31 19:06:21.403021 [ 3830 ] {aca07bcd-b86f-40e0-9d88-5c68cbb0e226} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.422694 [ 3830 ] {3b890a04-a7c4-4df4-8b65-d0797ebb14b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 0, should be 1: In scope SELECT toNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toNullable();) 2025.03.31 19:06:21.424482 [ 3830 ] {3b890a04-a7c4-4df4-8b65-d0797ebb14b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 0, should be 1: In scope SELECT toNullable(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.439355 [ 3830 ] {66fa92ed-1d32-42ad-a7fe-54e71224c377} executeQuery: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toQuarter();) 2025.03.31 19:06:21.440988 [ 3830 ] {66fa92ed-1d32-42ad-a7fe-54e71224c377} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.586193 [ 3830 ] {7d1bed2a-62be-4e16-bb45-823e14502c1f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeDayNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeDayNum();) 2025.03.31 19:06:21.588010 [ 3830 ] {7d1bed2a-62be-4e16-bb45-823e14502c1f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeDayNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeDayNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.600597 [ 3830 ] {54692d57-028e-416a-a3bd-e098e130a40a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeHourNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeHourNum();) 2025.03.31 19:06:21.602335 [ 3830 ] {54692d57-028e-416a-a3bd-e098e130a40a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeHourNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeHourNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.615052 [ 3830 ] {4607464b-32d6-4534-8339-94c054e8155c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMinuteNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeMinuteNum();) 2025.03.31 19:06:21.616472 [ 3830 ] {4607464b-32d6-4534-8339-94c054e8155c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMinuteNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMinuteNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.628328 [ 3830 ] {4b664b0b-50c2-49ee-9a76-475ce0fc140a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMonthNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeMonthNum();) 2025.03.31 19:06:21.629900 [ 3830 ] {4b664b0b-50c2-49ee-9a76-475ce0fc140a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeMonthNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeMonthNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.643050 [ 3830 ] {8a2cfd64-3046-4c75-9431-a731c7230dd0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeQuarterNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeQuarterNum();) 2025.03.31 19:06:21.644377 [ 3830 ] {8a2cfd64-3046-4c75-9431-a731c7230dd0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeQuarterNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeQuarterNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.754834 [ 3830 ] {d219b166-36c2-4349-9b0f-f3c51bf8fbaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeSecondNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeSecondNum();) 2025.03.31 19:06:21.756587 [ 3830 ] {d219b166-36c2-4349-9b0f-f3c51bf8fbaa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeSecondNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeSecondNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.770942 [ 3830 ] {7b278b16-5832-400c-8f5f-9bef888a63a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeWeekNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeWeekNum();) 2025.03.31 19:06:21.772711 [ 3830 ] {7b278b16-5832-400c-8f5f-9bef888a63a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeWeekNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeWeekNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.813136 [ 3830 ] {293e2654-cdb7-4d88-b8ef-db34b049a709} executeQuery: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeYearNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toRelativeYearNum();) 2025.03.31 19:06:21.814863 [ 3830 ] {293e2654-cdb7-4d88-b8ef-db34b049a709} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toRelativeYearNum doesn't match: passed 0, should be 1 or 2: In scope SELECT toRelativeYearNum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.868768 [ 3830 ] {671dbe9f-d949-4952-a9e7-0a5c79cb7ea8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toSecond();) 2025.03.31 19:06:21.870324 [ 3830 ] {671dbe9f-d949-4952-a9e7-0a5c79cb7ea8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.883254 [ 3830 ] {96ddc498-16be-43ae-9553-3dafda205b3f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfDay();) 2025.03.31 19:06:21.884812 [ 3830 ] {96ddc498-16be-43ae-9553-3dafda205b3f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfDay doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfDay(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.909078 [ 3830 ] {675b0190-08d9-41b6-b8e8-8f7147e5fe8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfFifteenMinutes();) 2025.03.31 19:06:21.910743 [ 3830 ] {675b0190-08d9-41b6-b8e8-8f7147e5fe8d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFifteenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFifteenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.924951 [ 3830 ] {a35e6d7c-5d0c-4b06-85d3-8bf49d3aa416} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfFiveMinute();) 2025.03.31 19:06:21.926782 [ 3830 ] {a35e6d7c-5d0c-4b06-85d3-8bf49d3aa416} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.938715 [ 3830 ] {af6c4a18-7215-4292-bb23-be9db4f09aed} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfFiveMinutes();) 2025.03.31 19:06:21.941920 [ 3830 ] {af6c4a18-7215-4292-bb23-be9db4f09aed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfFiveMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfFiveMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.953028 [ 3830 ] {15fa72aa-ab60-4b5f-aae7-9bc0f05de5a0} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfHour();) 2025.03.31 19:06:21.954322 [ 3830 ] {15fa72aa-ab60-4b5f-aae7-9bc0f05de5a0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfHour doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfHour(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.963742 [ 3830 ] {f76b1733-5f6e-40d1-a496-a496bbbaf930} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfISOYear();) 2025.03.31 19:06:21.964703 [ 3830 ] {f76b1733-5f6e-40d1-a496-a496bbbaf930} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfISOYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfISOYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:21.975206 [ 3830 ] {2680cb9e-ee0d-40ca-b847-357bd53e8d21} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 0, should be 2 or 3: In scope SELECT toStartOfInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfInterval();) 2025.03.31 19:06:21.976134 [ 3830 ] {2680cb9e-ee0d-40ca-b847-357bd53e8d21} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 0, should be 2 or 3: In scope SELECT toStartOfInterval(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.051124 [ 3830 ] {28ae26a6-7d84-44ee-a84f-81caf9562d9d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfMicrosecond();) 2025.03.31 19:06:22.053051 [ 3830 ] {28ae26a6-7d84-44ee-a84f-81caf9562d9d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMicrosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMicrosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.138718 [ 3830 ] {1536748d-9480-458b-a5f5-fd7aed2b2ab6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfMillisecond();) 2025.03.31 19:06:22.140267 [ 3830 ] {1536748d-9480-458b-a5f5-fd7aed2b2ab6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.154384 [ 3830 ] {4f9188af-02cf-4418-b371-c5cca670d1b6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfMinute();) 2025.03.31 19:06:22.156039 [ 3830 ] {4f9188af-02cf-4418-b371-c5cca670d1b6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMinute doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMinute(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.169360 [ 3830 ] {f6cf6912-ca36-4444-8ab5-23fd77134cd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfMonth();) 2025.03.31 19:06:22.171195 [ 3830 ] {f6cf6912-ca36-4444-8ab5-23fd77134cd7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfMonth doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfMonth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.184995 [ 3830 ] {af19525e-219f-4645-82e6-fd4c95501a62} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfNanosecond();) 2025.03.31 19:06:22.186597 [ 3830 ] {af19525e-219f-4645-82e6-fd4c95501a62} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfNanosecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfNanosecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.200046 [ 3830 ] {db6f18ce-35f8-4e7b-9ec3-af148b1195ee} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfQuarter();) 2025.03.31 19:06:22.201701 [ 3830 ] {db6f18ce-35f8-4e7b-9ec3-af148b1195ee} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfQuarter doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfQuarter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.224791 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:22.232777 [ 3830 ] {fa1148c7-e1cf-4826-87bf-fbbba4eceb18} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfSecond();) 2025.03.31 19:06:22.234384 [ 3830 ] {fa1148c7-e1cf-4826-87bf-fbbba4eceb18} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfSecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfSecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.248054 [ 3830 ] {81245c89-8362-4346-8107-9524e5c744a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfTenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfTenMinutes();) 2025.03.31 19:06:22.249584 [ 3830 ] {81245c89-8362-4346-8107-9524e5c744a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfTenMinutes doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfTenMinutes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.263323 [ 3830 ] {d572b82e-b4c7-4d7e-91c2-2e49a8d8c20c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toStartOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfWeek();) 2025.03.31 19:06:22.265516 [ 3830 ] {d572b82e-b4c7-4d7e-91c2-2e49a8d8c20c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toStartOfWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.279951 [ 3830 ] {c9de9801-1ae4-402e-aa3b-039b7393e91d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStartOfYear();) 2025.03.31 19:06:22.281553 [ 3830 ] {c9de9801-1ae4-402e-aa3b-039b7393e91d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toStartOfYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.296664 [ 3830 ] {6eb81541-d0ad-4810-93d1-9bc3ad9d4670} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 0 arguments: In scope SELECT toString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toString();) 2025.03.31 19:06:22.298668 [ 3830 ] {6eb81541-d0ad-4810-93d1-9bc3ad9d4670} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 0 arguments: In scope SELECT toString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.313083 [ 3830 ] {4206bf22-6e15-467d-9d46-26c30ff3a259} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 0, should be 1: In scope SELECT toStringCutToZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toStringCutToZero();) 2025.03.31 19:06:22.314823 [ 3830 ] {4206bf22-6e15-467d-9d46-26c30ff3a259} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 0, should be 1: In scope SELECT toStringCutToZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.379516 [ 3830 ] {76639cef-83f4-407b-8873-d7dec48b5ea3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 0, should be 1 or 2: In scope SELECT toTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toTime();) 2025.03.31 19:06:22.381186 [ 3830 ] {76639cef-83f4-407b-8873-d7dec48b5ea3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTime doesn't match: passed 0, should be 1 or 2: In scope SELECT toTime(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.417400 [ 3830 ] {ba04b44b-dd4c-4495-8c79-209946404e6d} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimeZone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toTimeZone();) 2025.03.31 19:06:22.419494 [ 3830 ] {ba04b44b-dd4c-4495-8c79-209946404e6d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimeZone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.457621 [ 3830 ] {132fcd7a-f85a-4e4e-b93f-a9ca74ccdcdb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimezone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toTimezone();) 2025.03.31 19:06:22.459327 [ 3830 ] {132fcd7a-f85a-4e4e-b93f-a9ca74ccdcdb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTimezone doesn't match: passed 0, should be 2: In scope SELECT toTimezone(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.472855 [ 3830 ] {12731456-c1c3-4059-b3c6-48b8daa24873} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 0, should be 1: In scope SELECT toTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toTypeName();) 2025.03.31 19:06:22.474450 [ 3830 ] {12731456-c1c3-4059-b3c6-48b8daa24873} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 0, should be 1: In scope SELECT toTypeName(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.505191 [ 3830 ] {8fed7641-7d76-42ac-b094-7fa224e6e72d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt128();) 2025.03.31 19:06:22.506983 [ 3830 ] {8fed7641-7d76-42ac-b094-7fa224e6e72d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt128(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.521584 [ 3830 ] {ac4aaa20-5151-4e46-b057-6af1c42debea} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt128OrDefault();) 2025.03.31 19:06:22.523201 [ 3830 ] {ac4aaa20-5151-4e46-b057-6af1c42debea} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt128OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.597632 [ 3830 ] {e8d59f13-08c4-4020-ade1-6f1aaf6b9a6a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt128OrNull();) 2025.03.31 19:06:22.599328 [ 3830 ] {e8d59f13-08c4-4020-ade1-6f1aaf6b9a6a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.611986 [ 3830 ] {c3556423-d33d-4cfc-adb1-eab5b429033c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt128OrZero();) 2025.03.31 19:06:22.613643 [ 3830 ] {c3556423-d33d-4cfc-adb1-eab5b429033c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt128OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt128OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.626509 [ 3830 ] {ac07c10b-5fef-4ae6-9a82-c0cbb60ee2b6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt16();) 2025.03.31 19:06:22.628017 [ 3830 ] {ac07c10b-5fef-4ae6-9a82-c0cbb60ee2b6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt16(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.640886 [ 3830 ] {95866421-8330-4e01-80ae-5258b22d7ea8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt16OrDefault();) 2025.03.31 19:06:22.642580 [ 3830 ] {95866421-8330-4e01-80ae-5258b22d7ea8} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt16OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.697669 [ 3830 ] {0cd4e926-2761-4a20-ada4-9ab2179913e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt16OrNull();) 2025.03.31 19:06:22.700110 [ 3830 ] {0cd4e926-2761-4a20-ada4-9ab2179913e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.713968 [ 3830 ] {f3df27a2-38ee-49bd-a7fd-9bcebfc8f0d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt16OrZero();) 2025.03.31 19:06:22.715694 [ 3830 ] {f3df27a2-38ee-49bd-a7fd-9bcebfc8f0d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt16OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt16OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.730410 [ 3830 ] {4a54d12a-2a02-4c7e-931c-7f60db8036b5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt256();) 2025.03.31 19:06:22.731989 [ 3830 ] {4a54d12a-2a02-4c7e-931c-7f60db8036b5} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt256(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.746254 [ 3830 ] {258ab4cc-320f-4e0b-b15e-1cf9d9237eb1} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt256OrDefault();) 2025.03.31 19:06:22.747716 [ 3830 ] {258ab4cc-320f-4e0b-b15e-1cf9d9237eb1} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt256OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.856356 [ 3830 ] {c5982b93-0737-4241-811d-0c8aef93ef01} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt256OrNull();) 2025.03.31 19:06:22.858092 [ 3830 ] {c5982b93-0737-4241-811d-0c8aef93ef01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.903185 [ 3830 ] {26689ab0-2742-45af-b4ed-155d767bb08f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt256OrZero();) 2025.03.31 19:06:22.905050 [ 3830 ] {26689ab0-2742-45af-b4ed-155d767bb08f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt256OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt256OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.918563 [ 3830 ] {0b0ec0df-58bf-42b4-aa85-6cbcc27a0b1b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt32();) 2025.03.31 19:06:22.921692 [ 3830 ] {0b0ec0df-58bf-42b4-aa85-6cbcc27a0b1b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt32(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.934433 [ 3830 ] {476ad07f-b336-4f2d-a51a-1d0f219c90b9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt32OrDefault();) 2025.03.31 19:06:22.935925 [ 3830 ] {476ad07f-b336-4f2d-a51a-1d0f219c90b9} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt32OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.949257 [ 3830 ] {9b402a6e-6d79-4c7c-afda-38921563199a} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt32OrNull();) 2025.03.31 19:06:22.951093 [ 3830 ] {9b402a6e-6d79-4c7c-afda-38921563199a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.966136 [ 3830 ] {c236e0c2-7ea8-449e-bcf4-fa2f6fa86e63} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt32OrZero();) 2025.03.31 19:06:22.967782 [ 3830 ] {c236e0c2-7ea8-449e-bcf4-fa2f6fa86e63} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt32OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt32OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.981892 [ 3830 ] {95780604-f8f5-4cb1-8182-7ce26ffe1c36} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt64();) 2025.03.31 19:06:22.983506 [ 3830 ] {95780604-f8f5-4cb1-8182-7ce26ffe1c36} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt64(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:22.996494 [ 3830 ] {183294ef-e5eb-43c8-8cce-131336171402} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt64OrDefault();) 2025.03.31 19:06:22.998352 [ 3830 ] {183294ef-e5eb-43c8-8cce-131336171402} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt64OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.012211 [ 3830 ] {72b06432-2b4d-4277-add0-1cc69a807562} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt64OrNull();) 2025.03.31 19:06:23.014104 [ 3830 ] {72b06432-2b4d-4277-add0-1cc69a807562} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.028725 [ 3830 ] {4487295c-b1ec-485f-a5da-7c973215f35e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt64OrZero();) 2025.03.31 19:06:23.030530 [ 3830 ] {4487295c-b1ec-485f-a5da-7c973215f35e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt64OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt64OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.044651 [ 3830 ] {59584fc0-48ba-4271-81e1-bc202344aef7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt8();) 2025.03.31 19:06:23.101165 [ 3830 ] {59584fc0-48ba-4271-81e1-bc202344aef7} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 0 arguments: In scope SELECT toUInt8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.114547 [ 3830 ] {8ca65f95-4ebb-4894-9c92-183eed504e8f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt8OrDefault();) 2025.03.31 19:06:23.115913 [ 3830 ] {8ca65f95-4ebb-4894-9c92-183eed504e8f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8OrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUInt8OrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.130374 [ 3830 ] {78c98baa-d36f-484f-8763-10a8911ef7f6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt8OrNull();) 2025.03.31 19:06:23.131952 [ 3830 ] {78c98baa-d36f-484f-8763-10a8911ef7f6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.213358 [ 3830 ] {60553325-471d-4c38-ae7c-bdea92b4981f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUInt8OrZero();) 2025.03.31 19:06:23.215132 [ 3830 ] {60553325-471d-4c38-ae7c-bdea92b4981f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUInt8OrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUInt8OrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.283499 [ 3830 ] {15f50f88-146d-4d59-abbf-296f888335c1} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT toUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUTCTimestamp();) 2025.03.31 19:06:23.285159 [ 3830 ] {15f50f88-146d-4d59-abbf-296f888335c1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT toUTCTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.346843 [ 3830 ] {973caed1-989e-43ca-a5e4-6548af2153c4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 0 arguments: In scope SELECT toUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUUID();) 2025.03.31 19:06:23.348385 [ 3830 ] {973caed1-989e-43ca-a5e4-6548af2153c4} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 0 arguments: In scope SELECT toUUID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.361205 [ 3830 ] {fdd45259-a94a-4cf5-89eb-0237fc828a77} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUUIDOrDefault();) 2025.03.31 19:06:23.363104 [ 3830 ] {fdd45259-a94a-4cf5-89eb-0237fc828a77} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUIDOrDefault'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUUIDOrDefault(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.372691 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:23.375986 [ 3830 ] {c991530b-21b6-43ba-8ac3-6211a80abf6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUUIDOrNull();) 2025.03.31 19:06:23.377487 [ 3830 ] {c991530b-21b6-43ba-8ac3-6211a80abf6c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrNull doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrNull(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.430740 [ 3830 ] {ab1c4f5c-a3cb-4c92-af1c-0c48f41c42d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUUIDOrZero();) 2025.03.31 19:06:23.432274 [ 3830 ] {ab1c4f5c-a3cb-4c92-af1c-0c48f41c42d6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUUIDOrZero doesn't match: passed 0, should be 1 or 2. Second argument only make sense for DateTime (time zone, optional) and Decimal (scale).: In scope SELECT toUUIDOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.445225 [ 3830 ] {a6900d4c-c789-4cce-8b05-25839c8f58d0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUnixTimestamp();) 2025.03.31 19:06:23.446953 [ 3830 ] {a6900d4c-c789-4cce-8b05-25839c8f58d0} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUnixTimestamp'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT toUnixTimestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.459722 [ 3830 ] {63b634b6-5cc4-42b5-afb1-07c537926039} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUnixTimestamp64Micro();) 2025.03.31 19:06:23.461279 [ 3830 ] {63b634b6-5cc4-42b5-afb1-07c537926039} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Micro(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.478273 [ 3830 ] {22b733cf-c04e-4c6d-a218-018a6d344937} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUnixTimestamp64Milli();) 2025.03.31 19:06:23.479812 [ 3830 ] {22b733cf-c04e-4c6d-a218-018a6d344937} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Milli(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.493497 [ 3830 ] {70ca98f8-1462-4d7c-a92c-4bf1727700eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toUnixTimestamp64Nano();) 2025.03.31 19:06:23.495396 [ 3830 ] {70ca98f8-1462-4d7c-a92c-4bf1727700eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 0, should be 1: In scope SELECT toUnixTimestamp64Nano(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.509153 [ 3830 ] {0ec6edaf-6ef9-4d10-972a-c4ebace81baa} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT toValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toValidUTF8();) 2025.03.31 19:06:23.511038 [ 3830 ] {0ec6edaf-6ef9-4d10-972a-c4ebace81baa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 0, should be 1: In scope SELECT toValidUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.525065 [ 3830 ] {3acd24f2-f3da-4793-951c-8ce40df49f03} executeQuery: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toWeek();) 2025.03.31 19:06:23.529449 [ 3830 ] {3acd24f2-f3da-4793-951c-8ce40df49f03} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.542928 [ 3830 ] {79ea0b9e-8ffd-4fd1-9099-bde7d66bbae7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toYYYYMM();) 2025.03.31 19:06:23.544701 [ 3830 ] {79ea0b9e-8ffd-4fd1-9099-bde7d66bbae7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMM doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMM(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.558951 [ 3830 ] {6712ea75-d4fa-4e42-b887-d8adacf42819} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toYYYYMMDD();) 2025.03.31 19:06:23.560465 [ 3830 ] {6712ea75-d4fa-4e42-b887-d8adacf42819} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDD doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDD(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.574923 [ 3830 ] {2cbf7583-a388-4872-86d0-9af92d1fcab6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toYYYYMMDDhhmmss();) 2025.03.31 19:06:23.576638 [ 3830 ] {2cbf7583-a388-4872-86d0-9af92d1fcab6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYYYYMMDDhhmmss doesn't match: passed 0, should be 1 or 2: In scope SELECT toYYYYMMDDhhmmss(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.590009 [ 3830 ] {a02b0734-997d-41bb-b085-87db3033cd60} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toYear();) 2025.03.31 19:06:23.591549 [ 3830 ] {a02b0734-997d-41bb-b085-87db3033cd60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYear doesn't match: passed 0, should be 1 or 2: In scope SELECT toYear(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.605292 [ 3830 ] {b9dbe884-250f-40a4-a1f5-83bfc56da1ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toYearWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT toYearWeek();) 2025.03.31 19:06:23.606991 [ 3830 ] {b9dbe884-250f-40a4-a1f5-83bfc56da1ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT toYearWeek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.660736 [ 3830 ] {3989e7fc-e120-4d9e-aaa5-bbc182c74b3e} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT to_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT to_utc_timestamp();) 2025.03.31 19:06:23.662477 [ 3830 ] {3989e7fc-e120-4d9e-aaa5-bbc182c74b3e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUTCTimestamp doesn't match: passed 0, should be 2: In scope SELECT to_utc_timestamp(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.784637 [ 3830 ] {1f6ff820-7e8b-4874-b7aa-d9c42b47e17b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 0, should be 1: In scope SELECT tokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tokens();) 2025.03.31 19:06:23.786308 [ 3830 ] {1f6ff820-7e8b-4874-b7aa-d9c42b47e17b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 0, should be 1: In scope SELECT tokens(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.847000 [ 3830 ] {fa7cd4d6-9173-4260-96f8-51857c6f76c4} executeQuery: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT topK();) 2025.03.31 19:06:23.848578 [ 3830 ] {fa7cd4d6-9173-4260-96f8-51857c6f76c4} TCPHandler: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.924353 [ 3830 ] {518437e2-8768-431b-9e3b-fa26c77cfe46} executeQuery: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT topKWeighted();) 2025.03.31 19:06:23.926078 [ 3830 ] {518437e2-8768-431b-9e3b-fa26c77cfe46} TCPHandler: Code: 42. DB::Exception: Aggregate function topKWeighted requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.939277 [ 3830 ] {baec00da-63b3-49a3-90ce-b1310688d86e} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 0, should be 1: In scope SELECT topLevelDomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT topLevelDomain();) 2025.03.31 19:06:23.940800 [ 3830 ] {baec00da-63b3-49a3-90ce-b1310688d86e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 0, should be 1: In scope SELECT topLevelDomain(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:23.953219 [ 3830 ] {d01737f6-c7ae-4005-92b7-42e384838013} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 0, should be 1: In scope SELECT topLevelDomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT topLevelDomainRFC();) 2025.03.31 19:06:23.954840 [ 3830 ] {d01737f6-c7ae-4005-92b7-42e384838013} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 0, should be 1: In scope SELECT topLevelDomainRFC(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.040879 [ 3830 ] {1081a66f-8e85-4ea8-8159-0df920036cc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 0, should be 3 or 4: In scope SELECT transform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT transform();) 2025.03.31 19:06:24.042437 [ 3830 ] {1081a66f-8e85-4ea8-8159-0df920036cc0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 0, should be 3 or 4: In scope SELECT transform(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.055808 [ 3830 ] {e86e701b-a7a3-4d58-b212-3d99e878c516} executeQuery: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 0, should be 3: In scope SELECT translate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT translate();) 2025.03.31 19:06:24.057293 [ 3830 ] {e86e701b-a7a3-4d58-b212-3d99e878c516} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 0, should be 3: In scope SELECT translate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.069999 [ 3830 ] {3b873f4d-c6d6-4a42-a83c-17a89d2bb236} executeQuery: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 0, should be 3: In scope SELECT translateUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT translateUTF8();) 2025.03.31 19:06:24.071522 [ 3830 ] {3b873f4d-c6d6-4a42-a83c-17a89d2bb236} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 0, should be 3: In scope SELECT translateUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.084144 [ 3830 ] {f85f5f50-b79c-46d4-aee7-2d11775e13e9} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 0, should be 1: In scope SELECT trimBoth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT trimBoth();) 2025.03.31 19:06:24.085480 [ 3830 ] {f85f5f50-b79c-46d4-aee7-2d11775e13e9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 0, should be 1: In scope SELECT trimBoth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.095984 [ 3830 ] {8701afba-e5f1-4d5a-a1d2-c35ec87a6506} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 0, should be 1: In scope SELECT trimLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT trimLeft();) 2025.03.31 19:06:24.097356 [ 3830 ] {8701afba-e5f1-4d5a-a1d2-c35ec87a6506} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 0, should be 1: In scope SELECT trimLeft(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.139263 [ 3830 ] {8e391101-2708-4e94-b878-f2f878d694c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 0, should be 1: In scope SELECT trimRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT trimRight();) 2025.03.31 19:06:24.140753 [ 3830 ] {8e391101-2708-4e94-b878-f2f878d694c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 0, should be 1: In scope SELECT trimRight(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.206461 [ 3830 ] {82b3daaf-fed3-4de4-aa6b-1da28cef3054} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT trunc();) 2025.03.31 19:06:24.208179 [ 3830 ] {82b3daaf-fed3-4de4-aa6b-1da28cef3054} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT trunc(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.246285 [ 3830 ] {8509bb83-799c-4685-b0ce-7bf2c53b5096} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT truncate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT truncate();) 2025.03.31 19:06:24.248036 [ 3830 ] {8509bb83-799c-4685-b0ce-7bf2c53b5096} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'trunc'. Expected 1 mandatory argument and 1 optional argument, got 0 arguments: In scope SELECT truncate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.321968 [ 3830 ] {bfe8d026-8f8c-4b57-ab86-3ca0c0f1cff6} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryBase58Decode();) 2025.03.31 19:06:24.323704 [ 3830 ] {bfe8d026-8f8c-4b57-ab86-3ca0c0f1cff6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase58Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.336668 [ 3830 ] {b0a6a82f-b205-4e10-974e-80ccc2e98fd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryBase64Decode();) 2025.03.31 19:06:24.338658 [ 3830 ] {b0a6a82f-b205-4e10-974e-80ccc2e98fd1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 0, should be 1: In scope SELECT tryBase64Decode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.351696 [ 3830 ] {419b6853-6ef7-43ed-a296-bd098a75b548} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryBase64URLDecode();) 2025.03.31 19:06:24.353246 [ 3830 ] {419b6853-6ef7-43ed-a296-bd098a75b548} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 0, should be 1: In scope SELECT tryBase64URLDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.410668 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:24.411199 [ 3830 ] {1f564658-1846-48c6-bf15-944bcda63301} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT tryDecrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryDecrypt();) 2025.03.31 19:06:24.413057 [ 3830 ] {1f564658-1846-48c6-bf15-944bcda63301} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 0 arguments: In scope SELECT tryDecrypt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.479017 [ 3830 ] {446cec86-c164-4054-954d-6e0529f74d0b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 0, should be 1: In scope SELECT tryIdnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryIdnaEncode();) 2025.03.31 19:06:24.480409 [ 3830 ] {446cec86-c164-4054-954d-6e0529f74d0b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 0, should be 1: In scope SELECT tryIdnaEncode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.494354 [ 3830 ] {71a51ad9-8a1c-471e-b187-3b73f53255c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 0, should be 1: In scope SELECT tryPunycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tryPunycodeDecode();) 2025.03.31 19:06:24.495932 [ 3830 ] {71a51ad9-8a1c-471e-b187-3b73f53255c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 0, should be 1: In scope SELECT tryPunycodeDecode(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.654176 [ 3830 ] {10eebbb2-fa51-4538-a654-22c6280998d6} executeQuery: Code: 42. DB::Exception: Number of arguments for function tumble doesn't match: passed 0, should be 2 or 3: In scope SELECT tumble(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tumble();) 2025.03.31 19:06:24.655598 [ 3830 ] {10eebbb2-fa51-4538-a654-22c6280998d6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tumble doesn't match: passed 0, should be 2 or 3: In scope SELECT tumble(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.668431 [ 3830 ] {a8a2e513-72ba-4458-8c76-e0f1550b1543} executeQuery: Code: 42. DB::Exception: Number of arguments for function tumbleEnd doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tumbleEnd();) 2025.03.31 19:06:24.670141 [ 3830 ] {a8a2e513-72ba-4458-8c76-e0f1550b1543} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tumbleEnd doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleEnd(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.683239 [ 3830 ] {d692dfa0-f99e-4352-bfe0-ff7147938961} executeQuery: Code: 42. DB::Exception: Number of arguments for function tumbleStart doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tumbleStart();) 2025.03.31 19:06:24.684948 [ 3830 ] {d692dfa0-f99e-4352-bfe0-ff7147938961} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tumbleStart doesn't match: passed 0, should be 2 or 3: In scope SELECT tumbleStart(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.721285 [ 3830 ] {5d8bece9-8e29-41f2-acc7-29731db396d8} executeQuery: Code: 42. DB::Exception: Function tupleConcat requires at least one argument.: In scope SELECT tupleConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleConcat();) 2025.03.31 19:06:24.723011 [ 3830 ] {5d8bece9-8e29-41f2-acc7-29731db396d8} TCPHandler: Code: 42. DB::Exception: Function tupleConcat requires at least one argument.: In scope SELECT tupleConcat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.738908 [ 3830 ] {da5d661d-b124-4cfa-bc3a-95acd6d9ff6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 0, should be 2: In scope SELECT tupleDivide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleDivide();) 2025.03.31 19:06:24.740560 [ 3830 ] {da5d661d-b124-4cfa-bc3a-95acd6d9ff6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivide doesn't match: passed 0, should be 2: In scope SELECT tupleDivide(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.754066 [ 3830 ] {eef8547b-332e-4635-ae9b-5fb3e1297572} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleDivideByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleDivideByNumber();) 2025.03.31 19:06:24.755649 [ 3830 ] {eef8547b-332e-4635-ae9b-5fb3e1297572} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleDivideByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleDivideByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.769655 [ 3830 ] {e3d20c54-e42e-49c1-8ec4-566bd44e1c5e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 0, should be 2 or 3: In scope SELECT tupleElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleElement();) 2025.03.31 19:06:24.771635 [ 3830 ] {e3d20c54-e42e-49c1-8ec4-566bd44e1c5e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 0, should be 2 or 3: In scope SELECT tupleElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.785487 [ 3830 ] {8718ae23-8509-40f7-be6b-9d71eccfbc03} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 0, should be 2: In scope SELECT tupleHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleHammingDistance();) 2025.03.31 19:06:24.787314 [ 3830 ] {8718ae23-8509-40f7-be6b-9d71eccfbc03} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleHammingDistance doesn't match: passed 0, should be 2: In scope SELECT tupleHammingDistance(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.800016 [ 3830 ] {2af21d3a-74fe-4ba5-9c3c-4a2bbcec1284} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 0, should be 2: In scope SELECT tupleIntDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleIntDiv();) 2025.03.31 19:06:24.801493 [ 3830 ] {2af21d3a-74fe-4ba5-9c3c-4a2bbcec1284} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDiv doesn't match: passed 0, should be 2: In scope SELECT tupleIntDiv(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.816098 [ 3830 ] {941b7eb5-cb51-4d18-b70d-f6ff35341d59} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleIntDivByNumber();) 2025.03.31 19:06:24.817654 [ 3830 ] {941b7eb5-cb51-4d18-b70d-f6ff35341d59} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.888244 [ 3830 ] {383fab1d-9b9c-4850-ab43-c232bcb88819} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleIntDivOrZero();) 2025.03.31 19:06:24.890062 [ 3830 ] {383fab1d-9b9c-4850-ab43-c232bcb88819} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZero doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.904463 [ 3830 ] {fd1c7801-339a-4a9f-9772-4a8ba437c319} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleIntDivOrZeroByNumber();) 2025.03.31 19:06:24.906405 [ 3830 ] {fd1c7801-339a-4a9f-9772-4a8ba437c319} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleIntDivOrZeroByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleIntDivOrZeroByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.920485 [ 3830 ] {6d876578-fd7b-43b8-9fbf-7bd365846bfa} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT tupleMinus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleMinus();) 2025.03.31 19:06:24.922380 [ 3830 ] {6d876578-fd7b-43b8-9fbf-7bd365846bfa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT tupleMinus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.935756 [ 3830 ] {306ca917-0865-47ad-a00d-248b3cbfd4ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 0, should be 2: In scope SELECT tupleModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleModulo();) 2025.03.31 19:06:24.937215 [ 3830 ] {306ca917-0865-47ad-a00d-248b3cbfd4ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModulo doesn't match: passed 0, should be 2: In scope SELECT tupleModulo(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.950340 [ 3830 ] {515bc3ef-b915-4522-bbf5-71dd75663331} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleModuloByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleModuloByNumber();) 2025.03.31 19:06:24.951868 [ 3830 ] {515bc3ef-b915-4522-bbf5-71dd75663331} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleModuloByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleModuloByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.965084 [ 3830 ] {750c1f30-faf9-4f5c-ac3c-98cb9340a19a} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 0, should be 2: In scope SELECT tupleMultiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleMultiply();) 2025.03.31 19:06:24.968916 [ 3830 ] {750c1f30-faf9-4f5c-ac3c-98cb9340a19a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiply doesn't match: passed 0, should be 2: In scope SELECT tupleMultiply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.980013 [ 3830 ] {789e7433-2f85-4d0c-9801-a135795f2f9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleMultiplyByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleMultiplyByNumber();) 2025.03.31 19:06:24.981500 [ 3830 ] {789e7433-2f85-4d0c-9801-a135795f2f9e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMultiplyByNumber doesn't match: passed 0, should be 2: In scope SELECT tupleMultiplyByNumber(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:24.994052 [ 3830 ] {02cd0ff9-7f64-4dc8-965f-7b55e60a7dde} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 0, should be 1: In scope SELECT tupleNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleNames();) 2025.03.31 19:06:24.995526 [ 3830 ] {02cd0ff9-7f64-4dc8-965f-7b55e60a7dde} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 0, should be 1: In scope SELECT tupleNames(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.007506 [ 3830 ] {42335532-05c9-4dcb-9d6d-5a43b311c4e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 0, should be 1: In scope SELECT tupleNegate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleNegate();) 2025.03.31 19:06:25.008942 [ 3830 ] {42335532-05c9-4dcb-9d6d-5a43b311c4e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 0, should be 1: In scope SELECT tupleNegate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.020392 [ 3830 ] {ab1b0cf8-4300-4860-87b5-628d660799b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT tuplePlus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tuplePlus();) 2025.03.31 19:06:25.022038 [ 3830 ] {ab1b0cf8-4300-4860-87b5-628d660799b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT tuplePlus(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.035106 [ 3830 ] {a11a6f4d-e10a-4441-8b68-8cdb4ce1d16e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 0, should be 1: In scope SELECT tupleToNameValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT tupleToNameValuePairs();) 2025.03.31 19:06:25.036508 [ 3830 ] {a11a6f4d-e10a-4441-8b68-8cdb4ce1d16e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 0, should be 1: In scope SELECT tupleToNameValuePairs(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.050791 [ 3830 ] {75ed9702-138c-46f7-ba1c-2eefad9a2799} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT ucase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT ucase();) 2025.03.31 19:06:25.052749 [ 3830 ] {75ed9702-138c-46f7-ba1c-2eefad9a2799} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT ucase(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.066330 [ 3830 ] {bb0464ac-b1e6-4fc9-a8a3-7a6778ce76e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 0, should be 1: In scope SELECT unbin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT unbin();) 2025.03.31 19:06:25.071756 [ 3830 ] {bb0464ac-b1e6-4fc9-a8a3-7a6778ce76e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 0, should be 1: In scope SELECT unbin(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.083857 [ 3830 ] {6c76c7ef-d5ae-4603-b211-b58958e4a07b} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 0, should be 1: In scope SELECT unhex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT unhex();) 2025.03.31 19:06:25.085307 [ 3830 ] {6c76c7ef-d5ae-4603-b211-b58958e4a07b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 0, should be 1: In scope SELECT unhex(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.098179 [ 3830 ] {425d59e6-b62b-4f3a-b64d-43106f65e7f8} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniq. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniq();) 2025.03.31 19:06:25.099789 [ 3830 ] {425d59e6-b62b-4f3a-b64d-43106f65e7f8} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniq. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.113149 [ 3830 ] {228ee2d0-cb1b-4285-a958-f08c619f07b7} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqCombined();) 2025.03.31 19:06:25.159080 [ 3830 ] {228ee2d0-cb1b-4285-a958-f08c619f07b7} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.172246 [ 3830 ] {465d279b-7a09-4b2f-a1a7-993f42ee51bd} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined64. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqCombined64();) 2025.03.31 19:06:25.173758 [ 3830 ] {465d279b-7a09-4b2f-a1a7-993f42ee51bd} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqCombined64. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.187194 [ 3830 ] {1ee7987a-63b3-4bc0-a252-62126b31c01d} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqExact. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqExact();) 2025.03.31 19:06:25.188745 [ 3830 ] {1ee7987a-63b3-4bc0-a252-62126b31c01d} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqExact. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.202508 [ 3830 ] {669ede89-6cf2-4124-ba22-6636cb196789} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqHLL12. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqHLL12();) 2025.03.31 19:06:25.204168 [ 3830 ] {669ede89-6cf2-4124-ba22-6636cb196789} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqHLL12. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.215953 [ 3830 ] {58b4d0d3-5740-4a70-a3e6-80a4ee510c73} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqTheta. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqTheta();) 2025.03.31 19:06:25.217953 [ 3830 ] {58b4d0d3-5740-4a70-a3e6-80a4ee510c73} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqTheta. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.235520 [ 3830 ] {29b4ffdc-e937-4879-947c-0d5389244fd8} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 0, should be 2: In scope SELECT uniqThetaIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqThetaIntersect();) 2025.03.31 19:06:25.237123 [ 3830 ] {29b4ffdc-e937-4879-947c-0d5389244fd8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaIntersect doesn't match: passed 0, should be 2: In scope SELECT uniqThetaIntersect(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.249465 [ 3830 ] {70cb8f5c-02b9-43ff-a84f-2d6b6f35ab92} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 0, should be 2: In scope SELECT uniqThetaNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqThetaNot();) 2025.03.31 19:06:25.250939 [ 3830 ] {70cb8f5c-02b9-43ff-a84f-2d6b6f35ab92} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaNot doesn't match: passed 0, should be 2: In scope SELECT uniqThetaNot(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.261911 [ 3830 ] {3fb73354-dd1f-4f36-9b5b-9e663349efe8} executeQuery: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 0, should be 2: In scope SELECT uniqThetaUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqThetaUnion();) 2025.03.31 19:06:25.263215 [ 3830 ] {3fb73354-dd1f-4f36-9b5b-9e663349efe8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uniqThetaUnion doesn't match: passed 0, should be 2: In scope SELECT uniqThetaUnion(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.274110 [ 3830 ] {5a32f83d-e3dc-4613-a35a-f489f0cec23a} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqUpTo. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT uniqUpTo();) 2025.03.31 19:06:25.275431 [ 3830 ] {5a32f83d-e3dc-4613-a35a-f489f0cec23a} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function uniqUpTo. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.288553 [ 3830 ] {85151b8e-6290-4995-86d5-4342f19eb8d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT upper(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT upper();) 2025.03.31 19:06:25.290660 [ 3830 ] {85151b8e-6290-4995-86d5-4342f19eb8d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 0, should be 1: In scope SELECT upper(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.302775 [ 3830 ] {7515125c-2adc-401d-9c64-a8ea18599252} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 0, should be 1: In scope SELECT upperUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT upperUTF8();) 2025.03.31 19:06:25.304222 [ 3830 ] {7515125c-2adc-401d-9c64-a8ea18599252} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 0, should be 1: In scope SELECT upperUTF8(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.452293 [ 3830 ] {25d018a7-3d79-4511-a839-444724ac74d0} executeQuery: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 0.: In scope SELECT validateNestedArraySizes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT validateNestedArraySizes();) 2025.03.31 19:06:25.454215 [ 3830 ] {25d018a7-3d79-4511-a839-444724ac74d0} TCPHandler: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 0.: In scope SELECT validateNestedArraySizes(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.474329 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:25.515491 [ 3830 ] {d6c6a989-f63e-4c73-929c-705d81456c09} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT varPop();) 2025.03.31 19:06:25.517013 [ 3830 ] {d6c6a989-f63e-4c73-929c-705d81456c09} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.627367 [ 3830 ] {888ce99f-8ae8-46b8-9e40-f555cf8be159} executeQuery: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT varPopStable();) 2025.03.31 19:06:25.629204 [ 3830 ] {888ce99f-8ae8-46b8-9e40-f555cf8be159} TCPHandler: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.688951 [ 3830 ] {8b9b8f05-3832-4428-841e-0aff982a0ea8} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT varSamp();) 2025.03.31 19:06:25.690917 [ 3830 ] {8b9b8f05-3832-4428-841e-0aff982a0ea8} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.704875 [ 3830 ] {6824ecde-8cff-41d2-a586-d36012677839} executeQuery: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT varSampStable();) 2025.03.31 19:06:25.706918 [ 3830 ] {6824ecde-8cff-41d2-a586-d36012677839} TCPHandler: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.812663 [ 3830 ] {fd67f8de-0df4-4f01-aafa-38425ce0d305} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantElement doesn't match: passed 0, should be 2 or 3: In scope SELECT variantElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT variantElement();) 2025.03.31 19:06:25.814494 [ 3830 ] {fd67f8de-0df4-4f01-aafa-38425ce0d305} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantElement doesn't match: passed 0, should be 2 or 3: In scope SELECT variantElement(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.828223 [ 3830 ] {5037198b-bea0-47a0-a060-1365208d8d68} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 0, should be 1: In scope SELECT variantType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT variantType();) 2025.03.31 19:06:25.830199 [ 3830 ] {5037198b-bea0-47a0-a060-1365208d8d68} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 0, should be 1: In scope SELECT variantType(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.862724 [ 3830 ] {eaf75e08-c72f-4b82-ad07-a5a4d7c69435} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT vectorDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT vectorDifference();) 2025.03.31 19:06:25.864335 [ 3830 ] {eaf75e08-c72f-4b82-ad07-a5a4d7c69435} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleMinus doesn't match: passed 0, should be 2: In scope SELECT vectorDifference(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.878955 [ 3830 ] {ec351fe8-b5a4-4918-8530-855b231f5a0c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT vectorSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT vectorSum();) 2025.03.31 19:06:25.880655 [ 3830 ] {ec351fe8-b5a4-4918-8530-855b231f5a0c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tuplePlus doesn't match: passed 0, should be 2: In scope SELECT vectorSum(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.930301 [ 3830 ] {fd03741e-eaed-4782-91de-5f5873fa3880} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 0, should be 1: In scope SELECT visibleWidth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visibleWidth();) 2025.03.31 19:06:25.932063 [ 3830 ] {fd03741e-eaed-4782-91de-5f5873fa3880} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 0, should be 1: In scope SELECT visibleWidth(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.944993 [ 3830 ] {c3878679-9b3c-4bf1-a24e-d36531599e32} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractBool();) 2025.03.31 19:06:25.946856 [ 3830 ] {c3878679-9b3c-4bf1-a24e-d36531599e32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractBool doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractBool(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.958998 [ 3830 ] {2ea58edf-aa2d-4b54-bcb7-922f528d2fc2} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractFloat();) 2025.03.31 19:06:25.960518 [ 3830 ] {2ea58edf-aa2d-4b54-bcb7-922f528d2fc2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractFloat doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractFloat(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:25.973614 [ 3830 ] {0b16ee4d-451f-4941-8245-ca74fdf504d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractInt();) 2025.03.31 19:06:25.975408 [ 3830 ] {0b16ee4d-451f-4941-8245-ca74fdf504d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.083684 [ 3830 ] {d4c1161f-220b-4b3a-948d-399679d14ac2} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractRaw();) 2025.03.31 19:06:26.085266 [ 3830 ] {d4c1161f-220b-4b3a-948d-399679d14ac2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractRaw doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractRaw(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.109434 [ 3830 ] {cec2050d-553a-4718-8d84-85983786edce} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractString();) 2025.03.31 19:06:26.111291 [ 3830 ] {cec2050d-553a-4718-8d84-85983786edce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractString doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractString(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.156888 [ 3830 ] {67d94bc9-6c0e-4faf-a783-57bdcc25ff48} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamExtractUInt();) 2025.03.31 19:06:26.158737 [ 3830 ] {67d94bc9-6c0e-4faf-a783-57bdcc25ff48} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONExtractUInt doesn't match: passed 0, should be 2: In scope SELECT visitParamExtractUInt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.170521 [ 3830 ] {99194dab-02df-4ac9-9546-4c60342e7792} executeQuery: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT visitParamHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT visitParamHas();) 2025.03.31 19:06:26.171962 [ 3830 ] {99194dab-02df-4ac9-9546-4c60342e7792} TCPHandler: Code: 42. DB::Exception: Number of arguments for function simpleJSONHas doesn't match: passed 0, should be 2: In scope SELECT visitParamHas(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.183636 [ 3830 ] {6792cd01-5e65-447d-a163-f5d3e145298c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT week(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT week();) 2025.03.31 19:06:26.185017 [ 3830 ] {6792cd01-5e65-447d-a163-f5d3e145298c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT week(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.296785 [ 3830 ] {c270e75b-6e3c-48a7-aaae-ce9051f802e3} executeQuery: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT welchTTest();) 2025.03.31 19:06:26.298647 [ 3830 ] {c270e75b-6e3c-48a7-aaae-ce9051f802e3} TCPHandler: Code: 42. DB::Exception: Aggregate function welchTTest requires two arguments. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.311265 [ 3830 ] {f5628c26-0978-4fb5-bf83-40a0d00f00b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT widthBucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT widthBucket();) 2025.03.31 19:06:26.312798 [ 3830 ] {f5628c26-0978-4fb5-bf83-40a0d00f00b7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT widthBucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.416071 [ 3830 ] {684edc77-ae86-4e0c-826a-4db6d9d41904} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT width_bucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT width_bucket();) 2025.03.31 19:06:26.417880 [ 3830 ] {684edc77-ae86-4e0c-826a-4db6d9d41904} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 0, should be 4: In scope SELECT width_bucket(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.430246 [ 3830 ] {ca946c43-d8f1-46ac-8e52-f436a75e4219} executeQuery: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT windowFunnel();) 2025.03.31 19:06:26.431909 [ 3830 ] {ca946c43-d8f1-46ac-8e52-f436a75e4219} TCPHandler: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.444987 [ 3830 ] {36afc8ca-cdec-4f59-9884-31efdb214e45} executeQuery: Code: 42. DB::Exception: Number of arguments for function windowID doesn't match: passed 0, should be 2, 3 or 4: In scope SELECT windowID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT windowID();) 2025.03.31 19:06:26.446826 [ 3830 ] {36afc8ca-cdec-4f59-9884-31efdb214e45} TCPHandler: Code: 42. DB::Exception: Number of arguments for function windowID doesn't match: passed 0, should be 2, 3 or 4: In scope SELECT windowID(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.459560 [ 3830 ] {13d43b73-bd0f-47ae-af92-2b6354895898} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 0, should be 1: In scope SELECT wkt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wkt();) 2025.03.31 19:06:26.461073 [ 3830 ] {13d43b73-bd0f-47ae-af92-2b6354895898} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 0, should be 1: In scope SELECT wkt(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:26.527376 [ 11058 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:26.529382 [ 3830 ] {def7ad34-9abc-46ed-a390-00e8f10d2180} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHash expect at least one argument: In scope SELECT wordShingleMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHash();) 2025.03.31 19:06:26.532699 [ 3830 ] {def7ad34-9abc-46ed-a390-00e8f10d2180} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHash expect at least one argument: In scope SELECT wordShingleMinHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.546059 [ 3830 ] {5759781a-aedd-483d-a667-51c7a50051cb} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArg expect at least one argument: In scope SELECT wordShingleMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashArg();) 2025.03.31 19:06:26.547906 [ 3830 ] {5759781a-aedd-483d-a667-51c7a50051cb} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArg expect at least one argument: In scope SELECT wordShingleMinHashArg(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.561419 [ 3830 ] {254a4a20-4e00-432f-b6ba-fdb65bf15ad2} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashArgCaseInsensitive();) 2025.03.31 19:06:26.563276 [ 3830 ] {254a4a20-4e00-432f-b6ba-fdb65bf15ad2} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.576002 [ 3830 ] {f171f134-8410-4882-9cdb-f5cbf1610f72} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashArgCaseInsensitiveUTF8();) 2025.03.31 19:06:26.577507 [ 3830 ] {f171f134-8410-4882-9cdb-f5cbf1610f72} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArgCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.636662 [ 3830 ] {5278d1cf-eaee-4856-a982-ff643fb997fc} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashArgUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashArgUTF8();) 2025.03.31 19:06:26.707194 [ 3830 ] {5278d1cf-eaee-4856-a982-ff643fb997fc} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashArgUTF8 expect at least one argument: In scope SELECT wordShingleMinHashArgUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.720428 [ 3830 ] {ae27f11f-c4ca-46d7-939e-ad5edc545424} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashCaseInsensitive();) 2025.03.31 19:06:26.722107 [ 3830 ] {ae27f11f-c4ca-46d7-939e-ad5edc545424} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.734440 [ 3830 ] {68d74761-3a1c-40db-b34a-3987ae52821c} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashCaseInsensitiveUTF8();) 2025.03.31 19:06:26.736300 [ 3830 ] {68d74761-3a1c-40db-b34a-3987ae52821c} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleMinHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.750162 [ 3830 ] {2ad58428-cfd2-43de-bc24-c36258e523de} executeQuery: Code: 35. DB::Exception: Function wordShingleMinHashUTF8 expect at least one argument: In scope SELECT wordShingleMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleMinHashUTF8();) 2025.03.31 19:06:26.751877 [ 3830 ] {2ad58428-cfd2-43de-bc24-c36258e523de} TCPHandler: Code: 35. DB::Exception: Function wordShingleMinHashUTF8 expect at least one argument: In scope SELECT wordShingleMinHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.798248 [ 3830 ] {50a527a1-5479-42d2-b046-e22505139269} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHash expect at least one argument: In scope SELECT wordShingleSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleSimHash();) 2025.03.31 19:06:26.800049 [ 3830 ] {50a527a1-5479-42d2-b046-e22505139269} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHash expect at least one argument: In scope SELECT wordShingleSimHash(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.812669 [ 3830 ] {855e7a71-5352-4ff3-a06f-a728b7681ff6} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleSimHashCaseInsensitive();) 2025.03.31 19:06:26.814433 [ 3830 ] {855e7a71-5352-4ff3-a06f-a728b7681ff6} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitive expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitive(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.826805 [ 3830 ] {814a53dd-4a8a-440c-96aa-deafc2ba97c5} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleSimHashCaseInsensitiveUTF8();) 2025.03.31 19:06:26.828252 [ 3830 ] {814a53dd-4a8a-440c-96aa-deafc2ba97c5} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHashCaseInsensitiveUTF8 expect at least one argument: In scope SELECT wordShingleSimHashCaseInsensitiveUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.841215 [ 3830 ] {244783bf-2043-498f-8c5f-a4a66adadfa8} executeQuery: Code: 35. DB::Exception: Function wordShingleSimHashUTF8 expect at least one argument: In scope SELECT wordShingleSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT wordShingleSimHashUTF8();) 2025.03.31 19:06:26.842969 [ 3830 ] {244783bf-2043-498f-8c5f-a4a66adadfa8} TCPHandler: Code: 35. DB::Exception: Function wordShingleSimHashUTF8 expect at least one argument: In scope SELECT wordShingleSimHashUTF8(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:26.881473 [ 3830 ] {ac8c57e0-8baa-486d-8653-13d9f97b33f7} executeQuery: Code: 35. DB::Exception: Number of arguments for function "xor" should be at least 2: passed 0: In scope SELECT xor(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT xor();) 2025.03.31 19:06:26.883265 [ 3830 ] {ac8c57e0-8baa-486d-8653-13d9f97b33f7} TCPHandler: Code: 35. DB::Exception: Number of arguments for function "xor" should be at least 2: passed 0: In scope SELECT xor(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.03.31 19:06:27.052231 [ 3830 ] {f90f2309-fcb1-41e4-a6d1-53332c6cac4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT yandexConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT yandexConsistentHash();) 2025.03.31 19:06:27.053672 [ 3830 ] {f90f2309-fcb1-41e4-a6d1-53332c6cac4a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function kostikConsistentHash doesn't match: passed 0, should be 2: In scope SELECT yandexConsistentHash(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:27.126487 [ 3830 ] {4dc697ad-1b8c-4ac9-99b3-23fe5a44f555} executeQuery: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT yearweek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46124) (comment: 00534_functions_bad_arguments2.sh) (in query: SELECT yearweek();) 2025.03.31 19:06:27.128069 [ 3830 ] {4dc697ad-1b8c-4ac9-99b3-23fe5a44f555} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toYearWeek doesn't match: passed 0, expected 1, 2 or 3.: In scope SELECT yearweek(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.03.31 19:06:27.674659 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:28.278361 [ 2854 ] {843dd059-89d6-4176-afb0-f931218bc5de} 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.10457.altinitytest (altinity build)) (from [::1]:53766) (comment: 02473_optimize_old_parts.sh) (in query: SELECT count(*) FROM system.parts WHERE database = currentDatabase() AND table='test_with_merge_limit' AND active), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:06:28.293980 [ 2854 ] {843dd059-89d6-4176-afb0-f931218bc5de} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:06:28.752062 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:29.799369 [ 11058 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:30.842873 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:31.158237 [ 4240 ] {0fb7dec2-fcda-411c-924f-e31708cda939} executeQuery: Code: 57. DB::Exception: Table test_1.trunc already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:53782) (comment: 01166_truncate_multiple_partitions.sql) (in query: create table trunc (n int, primary key n) partition by n % 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:06:31.159947 [ 4240 ] {0fb7dec2-fcda-411c-924f-e31708cda939} TCPHandler: Code: 57. DB::Exception: Table test_1.trunc 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:06:31.889509 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:32.976812 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:34.033268 [ 11058 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:35.149435 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:36.293006 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:36.784029 [ 3863 ] {34625eb6-284e-494f-bc2a-cb19660fdc45} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45152) (comment: 03032_async_backup_restore.sh) (in query: DROP DATABASE IF EXISTS test_lsupth4v ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:06:36.786235 [ 3863 ] {34625eb6-284e-494f-bc2a-cb19660fdc45} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:36.809110 [ 4240 ] {b297bab7-63b4-4718-9bcb-8794e1fae860} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45164) (comment: 03032_async_backup_restore.sh) (in query: DROP DATABASE IF EXISTS test_lsupth4v ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:06:36.811025 [ 4240 ] {b297bab7-63b4-4718-9bcb-8794e1fae860} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:37.333328 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:38.376423 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:38.965158 [ 11058 ] {d9ccdc60-6e3a-494d-83de-792e941f57ef} executeQuery: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 822850000 microseconds per block (of size 16457): while executing 'FUNCTION sleepEachRow(0.05_Float64 :: 1) -> sleepEachRow(0.05_Float64) UInt8 : 0'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60514) (comment: 02725_sleep_max_time.sql) (in query: SELECT * FROM system.numbers WHERE sleepEachRow(0.05) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b7f5261 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b7f4d44 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 19. ./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*) @ 0x000000003ae9f89d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 2025.03.31 19:06:38.967035 [ 11058 ] {d9ccdc60-6e3a-494d-83de-792e941f57ef} TCPHandler: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 822850000 microseconds per block (of size 16457): while executing 'FUNCTION sleepEachRow(0.05_Float64 :: 1) -> sleepEachRow(0.05_Float64) UInt8 : 0'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 11. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b7f5261 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b7f4d44 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 14. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 15. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 19. ./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*) @ 0x000000003ae9f89d 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 2025.03.31 19:06:39.461586 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:40.539256 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:41.594526 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:42.650755 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:42.693899 [ 2854 ] {197f016c-14f0-441f-b43e-08d6fcdf9ad5} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:43732) (comment: 00550_join_insert_select.sh) (in query: INSERT INTO test1_00550 SELECT id, name FROM test2_00550 ANY INNER JOIN test3_00550 USING (id) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:06:42.695846 [ 2854 ] {197f016c-14f0-441f-b43e-08d6fcdf9ad5} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:06:42.755717 [ 2854 ] {c065827d-c6b1-4f35-908f-25d61f46c686} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:43732) (comment: 00550_join_insert_select.sh) (in query: INSERT INTO test1_00550 SELECT id, name FROM test2_00550 ANY LEFT OUTER JOIN test3_00550 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:06:42.757445 [ 2854 ] {c065827d-c6b1-4f35-908f-25d61f46c686} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 2 and result: 1). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:06:43.777961 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:43.801098 [ 11058 ] {bcb12519-9771-4c05-91aa-5ef3290a03bd} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59952) (comment: 00550_join_insert_select.sh) (in query: DROP DATABASE IF EXISTS test_qy7tfkpi ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:06:43.803445 [ 11058 ] {bcb12519-9771-4c05-91aa-5ef3290a03bd} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:43.816447 [ 3212 ] {} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339b83d8 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339b942e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339da35f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 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*) @ 0x00000000319a464f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:44.831970 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:45.986659 [ 11058 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:47.040722 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:47.735016 [ 3600 ] {} 619209c2-c615-4ca3-a4f8-3e2ae285a71b::all_0_0_0_1 (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:47.735688 [ 3600 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {619209c2-c615-4ca3-a4f8-3e2ae285a71b::all_0_0_0_1}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:48.106178 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:49.132523 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:49.471788 [ 3607 ] {} 619209c2-c615-4ca3-a4f8-3e2ae285a71b::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039d03d22 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f91bf1 19. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000034f9c58b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e68dd2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e4e126 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a00057e 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffccec 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:49.472586 [ 3607 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {619209c2-c615-4ca3-a4f8-3e2ae285a71b::all_0_0_0_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039d03d22 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f91bf1 19. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000034f9c58b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e68dd2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 22. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e4e126 23. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a00057e 24. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffccec 25. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 26. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 31. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:49.625618 [ 3610 ] {} 619209c2-c615-4ca3-a4f8-3e2ae285a71b::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:49.626179 [ 3610 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {619209c2-c615-4ca3-a4f8-3e2ae285a71b::all_0_0_0_1}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:50.286623 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:51.324202 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:51.341259 [ 3603 ] {} 619209c2-c615-4ca3-a4f8-3e2ae285a71b::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 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) @ 0x0000000034f6039a 9. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000039e65536 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 11. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e4e126 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a00057e 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffccec 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:51.341920 [ 3603 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {619209c2-c615-4ca3-a4f8-3e2ae285a71b::all_0_0_0_1}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 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) @ 0x0000000034f6039a 9. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000039e65536 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 11. ./src/Storages/MergeTree/MutateFromLogEntryTask.h:44: DB::MutateFromLogEntryTask::executeInnerTask() @ 0x0000000039e4e126 12. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000003a00057e 13. ./build_docker/./src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:0: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000039ffccec 14. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 15. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:52.306728 [ 3596 ] {} 619209c2-c615-4ca3-a4f8-3e2ae285a71b::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:52.307212 [ 3596 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {619209c2-c615-4ca3-a4f8-3e2ae285a71b::all_0_0_0_1}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:52.404686 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:53.520250 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:54.749242 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:55.120748 [ 11058 ] {384d0c5f-3a9f-4483-952e-e97136be3801} executeQuery: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic, see allow_nondeterministic_mutations setting. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:43832) (comment: 02842_mutations_replace_non_deterministic.sql) (in query: -- Too big result. ALTER TABLE t_mutations_nondeterministic UPDATE v = (SELECT groupArray(number) FROM numbers(10000)) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::validate() @ 0x0000000034f9bc4f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854d3c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:06:55.122366 [ 11058 ] {384d0c5f-3a9f-4483-952e-e97136be3801} TCPHandler: Code: 36. DB::Exception: ALTER UPDATE/ALTER DELETE statement with subquery may be nondeterministic, see allow_nondeterministic_mutations setting. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::validate() @ 0x0000000034f9bc4f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854d3c 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:06:55.797312 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:56.068740 [ 4150 ] {} test_1.t_mutations_nondeterministic (a6b3ec21-4e10-486e-9ede-4730fce85468): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.03.31 19:06:56.715411 [ 12293 ] {cfc87a38-865c-4e32-b974-2450ae87195f} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39094) (comment: 01414_mutations_and_errors_zookeeper.sh) (in query: INSERT INTO replicated_mutation_table SELECT toDate('2019-10-02'), number, '42' FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003487a445 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba323f 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 2025.03.31 19:06:56.717283 [ 12293 ] {cfc87a38-865c-4e32-b974-2450ae87195f} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a)) does not support transactions. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003487a445 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba323f 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 2025.03.31 19:06:56.873065 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:57.315741 [ 4150 ] {} DatabaseCatalog: Cannot drop table test_1.t_mutations_nondeterministic (a6b3ec21-4e10-486e-9ede-4730fce85468). Will retry later.: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 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>*) @ 0x00000000397276a1 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>*) @ 0x0000000039720472 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2997: DB::MergeTreeData::dropAllData() @ 0x0000000039736baa 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1215: DB::StorageReplicatedMergeTree::drop() @ 0x0000000038756d01 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339b9fe2 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339daaa3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303ec68c 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()() @ 0x00000000303ec46d 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b123d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303eeb6e 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:57.526693 [ 2854 ] {07483e5c-6176-43da-8d5f-efe6cf706e0c} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39126) (comment: 01414_mutations_and_errors_zookeeper.sh) (in query: INSERT INTO replicated_mutation_table SELECT toDate('2019-10-02'), number, 'Hello' FROM numbers(10)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003487a445 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba323f 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 2025.03.31 19:06:57.528373 [ 2854 ] {07483e5c-6176-43da-8d5f-efe6cf706e0c} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a)) does not support transactions. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003487a445 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba323f 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 13. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 14. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 2025.03.31 19:06:57.900554 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:58.240018 [ 2854 ] {4641d384-44f4-441c-9874-87874782f4ef} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:36104) (comment: 02473_optimize_old_parts.sh) (in query: DROP DATABASE IF EXISTS test_iqg5y8dq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:06:58.242722 [ 2854 ] {4641d384-44f4-441c-9874-87874782f4ef} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:06:58.936318 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:06:59.003281 [ 4187 ] {ae710e62-4a3c-4887-ace4-810b22affa37} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39158) (comment: 01414_mutations_and_errors_zookeeper.sh) (in query: ALTER TABLE replicated_mutation_table UPDATE key = key + 1 WHERE sleepEachRow(3) == 0 SETTINGS mutations_sync = 2, function_sleep_max_microseconds_per_block=100000000), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003487a445 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034850156 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:06:59.005052 [ 4187 ] {ae710e62-4a3c-4887-ace4-810b22affa37} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a)) does not support transactions. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003487a445 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034850156 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:06:59.973431 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:01.002622 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:02.045008 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:03.172559 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:03.801077 [ 11058 ] {0b52bd15-a946-437c-b53f-defa5284f33b} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:43832) (comment: 02842_mutations_replace_non_deterministic.sql) (in query: CREATE TABLE t_mutations_nondeterministic (`id` UInt64, `v` DateTime) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/02842_mutations_replace', '1') ORDER BY id SETTINGS index_granularity = 9263, min_bytes_for_wide_part = 1057183040, ratio_of_defaults_for_sparse_serialization = 0.471591055393219, replace_long_file_name_to_hash = true, max_file_name_length = 66, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 324849157, compact_parts_max_granules_to_buffer = 183, compact_parts_merge_max_bytes_to_prefetch_part = 28672861, merge_max_block_size = 15494, 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 = 58, min_merge_bytes_to_use_direct_io = 3462046523, index_granularity_bytes = 16818318, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 13907, primary_key_compress_block_size = 90827), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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*&&, char const*&&, String&&, long&, String&&) @ 0x0000000020096687 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094fb3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000002018330a 9. ./src/IO/BufferWithOwnMemory.h:159: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x00000000202008f3 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x00000000201fe90d 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000002058d488 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&) @ 0x0000000032ec0ea3 13. ./build_docker/./src/Disks/DiskLocal.cpp:0: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000032ea9598 14. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:306: DB::MergeTreeData::initializeDirectoriesAndFormatVersion(String const&, bool, String const&, bool) @ 0x000000003969bc1e 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x00000000386d012d 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2bf3de 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aed93 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:07:03.802958 [ 11058 ] {0b52bd15-a946-437c-b53f-defa5284f33b} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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*&&, char const*&&, String&&, long&, String&&) @ 0x0000000020096687 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094fb3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000002018330a 9. ./src/IO/BufferWithOwnMemory.h:159: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x00000000202008f3 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x00000000201fe90d 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000002058d488 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&) @ 0x0000000032ec0ea3 13. ./build_docker/./src/Disks/DiskLocal.cpp:0: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000032ea9598 14. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:306: DB::MergeTreeData::initializeDirectoriesAndFormatVersion(String const&, bool, String const&, bool) @ 0x000000003969bc1e 15. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x00000000386d012d 16. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2bf3de 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aed93 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:07:04.337818 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:05.402068 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:06.499656 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:07.693523 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:08.745693 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:09.811306 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:09.946112 [ 12293 ] {242d27e8-dbd0-467a-82a5-6b77a8d6f9a8} 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.10457.altinitytest (altinity build)) (from [::1]:34472) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:09.948574 [ 12293 ] {242d27e8-dbd0-467a-82a5-6b77a8d6f9a8} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:10.841209 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:11.883872 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:12.903063 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:13.989326 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:15.013631 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:15.306604 [ 3830 ] {0906f6bc-5905-4371-b707-dbde44124455} 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.10457.altinitytest (altinity build)) (from [::1]:33572) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:15.309006 [ 3830 ] {0906f6bc-5905-4371-b707-dbde44124455} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:15.388177 [ 3863 ] {e8ea4dbe-ea24-4ecc-8444-8d4e99af7ade} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33626) (comment: 02179_bool_type.sql) (in query: SELECT toTypeName(0 or 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:15.390431 [ 3863 ] {e8ea4dbe-ea24-4ecc-8444-8d4e99af7ade} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:16.141836 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:17.256566 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:17.389190 [ 11058 ] {bfeef0cd-ae4b-415b-909c-49cc9febdcd0} executeQuery: Code: 60. DB::Exception: Table shard_1.data_01850 does not exist. Maybe you meant shard_0.data_01850?. (UNKNOWN_TABLE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33680) (comment: 01850_dist_INSERT_preserve_error.sql) (in query: INSERT INTO data_01850 (key) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008616c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b04dcc 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003398fd73 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a4c01 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x0000000034b8dd9b 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1211: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a1574 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:07:17.391052 [ 11058 ] {bfeef0cd-ae4b-415b-909c-49cc9febdcd0} TCPHandler: Code: 60. DB::Exception: Table shard_1.data_01850 does not exist. Maybe you meant shard_0.data_01850?. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008616c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b04dcc 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003398fd73 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a4c01 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x0000000034b8dd9b 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1211: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a1574 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:07:18.066184 [ 3863 ] {68a8e2fc-80b9-4e4a-865c-8df6f47fa233} executeQuery: Code: 60. DB::Exception: Received from localhost:9000. DB::Exception: Table shard_1.data_01850 does not exist. Maybe you meant shard_0.data_01850?. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008616c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b04dcc 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003398fd73 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a4c01 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x0000000034b8dd9b 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1211: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a1574 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 : Insertion status: Wrote 1 blocks and 1 rows on shard 0 replica 0, localhost:9000 (average 32 ms per block) Wrote 0 blocks and 0 rows on shard 0 replica 1, localhost:9000 (average 1133 ms per block) . (UNKNOWN_TABLE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33664) (comment: 01850_dist_INSERT_preserve_error.sql) (in query: insert into dist_01850 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:62: DB::RemoteInserter::RemoteInserter(DB::Connection&, DB::ConnectionTimeouts const&, String const&, DB::Settings const&, DB::ClientInfo const&) @ 0x00000000392ee690 6. ./src/Processors/Sinks/RemoteSink.h:19: std::shared_ptr std::allocate_shared[abi:v15007], DB::Connection&, DB::ConnectionTimeouts&, String&, DB::Settings const&, DB::ClientInfo const&, void>(std::allocator const&, DB::Connection&, DB::ConnectionTimeouts&, String&, DB::Settings const&, DB::ClientInfo const&) @ 0x0000000039334f43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003932ce61 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 13. ? @ 0x00007f038ce47ac3 14. ? @ 0x00007f038ced9850 2025.03.31 19:07:18.069072 [ 3863 ] {68a8e2fc-80b9-4e4a-865c-8df6f47fa233} TCPHandler: Code: 60. DB::Exception: Received from localhost:9000. DB::Exception: Table shard_1.data_01850 does not exist. Maybe you meant shard_0.data_01850?. Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x0000000008616c7f 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b04dcc 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003398fd73 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:955: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a4c01 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:173: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x0000000034b8dd9b 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1211: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a1574 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 : Insertion status: Wrote 1 blocks and 1 rows on shard 0 replica 0, localhost:9000 (average 32 ms per block) Wrote 0 blocks and 0 rows on shard 0 replica 1, localhost:9000 (average 1133 ms per block) . (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/QueryPipeline/RemoteInserter.cpp:62: DB::RemoteInserter::RemoteInserter(DB::Connection&, DB::ConnectionTimeouts const&, String const&, DB::Settings const&, DB::ClientInfo const&) @ 0x00000000392ee690 6. ./src/Processors/Sinks/RemoteSink.h:19: std::shared_ptr std::allocate_shared[abi:v15007], DB::Connection&, DB::ConnectionTimeouts&, String&, DB::Settings const&, DB::ClientInfo const&, void>(std::allocator const&, DB::Connection&, DB::ConnectionTimeouts&, String&, DB::Settings const&, DB::ClientInfo const&) @ 0x0000000039334f43 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003932ce61 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 9. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 11. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 13. ? @ 0x00007f038ce47ac3 14. ? @ 0x00007f038ced9850 2025.03.31 19:07:18.461979 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:18.913061 [ 3863 ] {} TCPHandler: Code: 101. DB::NetException: Unexpected packet Data 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./src/Common/Exception.h:0: _ZN2DB12NetExceptionC2IRA44_KcQsr3stdE16is_convertible_vIT_NSt3__112basic_stringIcNS6_11char_traitsIcEENS6_9allocatorIcEEEEEEEiOS5_ @ 0x000000003abf2956 3. ./build_docker/./src/Server/TCPHandler.cpp:2178: DB::TCPHandler::receiveUnexpectedData(bool) @ 0x000000003abe2204 4. ./build_docker/./src/Server/TCPHandler.cpp:1752: DB::TCPHandler::receivePacket() @ 0x000000003abb090c 5. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 7. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 9. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 10. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 11. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:19.036321 [ 3863 ] {37a48009-afe6-4fc8-89c2-fc415d766b29} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51950) (comment: 01850_dist_INSERT_preserve_error.sql) (in query: DROP DATABASE IF EXISTS test_xnuudygz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:07:19.038100 [ 3863 ] {37a48009-afe6-4fc8-89c2-fc415d766b29} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:07:19.508510 [ 3863 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:20.596081 [ 3863 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:21.006754 [ 3830 ] {e4c8227a-fb32-4775-97eb-8a6c49372f33} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33656) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:21.009140 [ 3830 ] {e4c8227a-fb32-4775-97eb-8a6c49372f33} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:21.658769 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:21.844332 [ 3863 ] {mysql:0:829dfa62-344f-4d48-9005-5ada275bad75} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57286) (in query: select a + b as b, count() from (select 1 as a, 1 as b) group by a + b), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000003aa9803f 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::run() @ 0x000000003aa8ba0b 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:21.908791 [ 3863 ] {} MySQLHandler: MySQLHandler: Cannot read packet: : 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5bddf 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&)>) @ 0x00000000358b2c73 11. ./build_docker/./src/Server/MySQLHandler.cpp:519: DB::MySQLHandler::comQuery(DB::ReadBuffer&, bool) @ 0x000000003aa9803f 12. ./build_docker/./src/Server/MySQLHandler.cpp:0: DB::MySQLHandler::run() @ 0x000000003aa8ba0b 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:07:22.742298 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:23.561631 [ 3830 ] {d5361b4c-71cc-4aa2-b68b-c18ecd38372f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33282) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:23.564293 [ 3830 ] {d5361b4c-71cc-4aa2-b68b-c18ecd38372f} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:23.878845 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:24.944797 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:25.155429 [ 4240 ] {67b8e95b-e238-46cb-81cb-da522cdeac98} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): (while reading column y): (while reading from part /var/lib/clickhouse/store/964/964c475f-8532-4792-9f45-29bc7dc6c0d3/all_1_1_0/ in table test_dwd1k1wn.t_delete_skip_index (964c475f-8532-4792-9f45-29bc7dc6c0d3) located on disk default of type local, from mark 4 with max_rows_to_read = 73728): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33304) (comment: 02832_alter_delete_indexes_projections.sql) (in query: select count() from t_delete_skip_index where y in (4, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003074f71a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003074ef60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003074b4d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x0000000030729b4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003072ac6f 11. DB::ReadBuffer::next() @ 0x00000000095afaaf 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320d5913 13. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000039cd9508 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000039cdadad 15. DB::ReadBuffer::next() @ 0x00000000095afaaf 16. ./src/IO/ReadBuffer.h:106: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000003282ca7d 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032829692 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 @ 0x00000000326328f0 19. ./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>>>*) @ 0x0000000039c6dc7d 20. ./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>>&) @ 0x0000000039cc67d1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c92952 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cb6136 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cae873 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d29606 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfa10d4 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b750 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 2025.03.31 19:07:25.158889 [ 4240 ] {67b8e95b-e238-46cb-81cb-da522cdeac98} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): (while reading column y): (while reading from part /var/lib/clickhouse/store/964/964c475f-8532-4792-9f45-29bc7dc6c0d3/all_1_1_0/ in table test_dwd1k1wn.t_delete_skip_index (964c475f-8532-4792-9f45-29bc7dc6c0d3) located on disk default of type local, from mark 4 with max_rows_to_read = 73728): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003074f71a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003074ef60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003074b4d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x0000000030729b4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003072ac6f 11. DB::ReadBuffer::next() @ 0x00000000095afaaf 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320d5913 13. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:52: DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000039cd9508 14. ./build_docker/./src/Compression/CachedCompressedReadBuffer.cpp:0: non-virtual thunk to DB::CachedCompressedReadBuffer::nextImpl() @ 0x0000000039cdadad 15. DB::ReadBuffer::next() @ 0x00000000095afaaf 16. ./src/IO/ReadBuffer.h:106: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x000000003282ca7d 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032829692 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 @ 0x00000000326328f0 19. ./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>>>*) @ 0x0000000039c6dc7d 20. ./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>>&) @ 0x0000000039cc67d1 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c92952 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cb6136 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cae873 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d29606 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfa10d4 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b750 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 28. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 29. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 2025.03.31 19:07:25.345559 [ 4240 ] {c1116830-e310-47ee-90a5-0acedae4dde9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40478) (comment: 02832_alter_delete_indexes_projections.sql) (in query: DROP DATABASE IF EXISTS test_dwd1k1wn ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:07:25.347708 [ 4240 ] {c1116830-e310-47ee-90a5-0acedae4dde9} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:07:25.372615 [ 12294 ] {07c6d8ca-7cf7-4f61-94b2-7a48f4319379} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40482) (comment: 02832_alter_delete_indexes_projections.sql) (in query: DROP DATABASE IF EXISTS test_dwd1k1wn ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:07:25.375669 [ 12294 ] {07c6d8ca-7cf7-4f61-94b2-7a48f4319379} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:07:26.102127 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:27.165873 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:27.218584 [ 3601 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d1eea20f-c94b-4f26-bb1f-af47f7265f25::202503_1_86_17}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:07:28.369311 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:29.445615 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:29.518668 [ 12293 ] {a08e4752-850a-4b57-8ee1-43946837047c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33344) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:29.520988 [ 12293 ] {a08e4752-850a-4b57-8ee1-43946837047c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:30.588667 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:31.535519 [ 12293 ] {9875ce9f-2f2f-447d-9a53-88a6f670d1c5} executeQuery: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (INVALID_WITH_FILL_EXPRESSION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:34912) (comment: 02561_with_fill_date_datetime_incompatible.sql) (in query: SELECT today() AS a ORDER BY a ASC WITH FILL FROM now() - toIntervalMonth(1) TO now() + toIntervalDay(1) STEP 82600;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003bdce768 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003bdc2113 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003bdc1105 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:591: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&)::$_0::operator()(DB::OutputPort*&, DB::Pipe::StreamType) const @ 0x000000003222e61c 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000003222e086 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:136: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000322851a1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003bdbf514 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be0514d 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:07:31.536717 [ 12293 ] {9875ce9f-2f2f-447d-9a53-88a6f670d1c5} TCPHandler: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Processors/Transforms/FillingTransform.cpp:226: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x000000003bdce768 5. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr, bool const&, void>(std::allocator const&, DB::Block const&, DB::SortDescription&, DB::SortDescription&, std::shared_ptr&&, bool const&) @ 0x000000003bdc2113 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x000000003bdc1105 7. ./build_docker/./src/QueryPipeline/Pipe.cpp:591: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&)::$_0::operator()(DB::OutputPort*&, DB::Pipe::StreamType) const @ 0x000000003222e61c 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:158: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x000000003222e086 9. ./build_docker/./src/QueryPipeline/QueryPipelineBuilder.cpp:136: DB::QueryPipelineBuilder::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x00000000322851a1 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000003bdbf514 11. ./build_docker/./src/Processors/QueryPlan/ITransformingStep.cpp:0: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be0514d 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:07:31.714824 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:31.885366 [ 12294 ] {6671a3fb-8a6e-4579-a6de-690f6b8c26b8} 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.10457.altinitytest (altinity build)) (from [::1]:34910) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:31.888269 [ 12294 ] {6671a3fb-8a6e-4579-a6de-690f6b8c26b8} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:32.745108 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:32.843872 [ 12294 ] {1402cd58-a328-4ef6-8bdc-934199de6440} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:34940) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:32.846588 [ 12294 ] {1402cd58-a328-4ef6-8bdc-934199de6440} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:33.293243 [ 12294 ] {5f5b84b3-85ff-4aa3-8a0c-50c2659e93c5} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:34970) (comment: 02579_fill_empty_chunk.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:33.295213 [ 12294 ] {5f5b84b3-85ff-4aa3-8a0c-50c2659e93c5} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:33.768943 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:34.972198 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:35.669065 [ 12293 ] {592dfff3-6951-4ecf-896c-df7f70b9b452} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:34982) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:35.671788 [ 12293 ] {592dfff3-6951-4ecf-896c-df7f70b9b452} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:36.018584 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:37.096410 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:37.567742 [ 12293 ] {c2e19bd1-219e-46a3-896e-688c99da4973} 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.10457.altinitytest (altinity build)) (from [::1]:35044) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:37.570241 [ 12293 ] {c2e19bd1-219e-46a3-896e-688c99da4973} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:07:37.764501 [ 2854 ] {210c8018-25dc-4bdb-a5f5-3c0bf92f3440} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): The table structure cannot be extracted from a TSV format file. You can specify the structure manually. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35038) (comment: 02245_s3_schema_desc.sql) (in query: DESCRIBE TABLE s3Cluster('test_cluster_two_shards_localhost', 'http://localhost:11111/test/{a,b,c}.tsv', 'test', '[HIDDEN]')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000030f0115a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030f009a0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030efd200 9. ./build_docker/./src/Disks/ObjectStorages/ObjectStorageIteratorAsync.cpp:0: DB::IObjectStorageIteratorAsync::getCurrentBatchAndScheduleNext() @ 0x0000000030eff3d5 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::StorageObjectStorageSource::GlobIterator::nextImplUnlocked(unsigned long) @ 0x0000000030a268ee 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:0: DB::StorageObjectStorageSource::GlobIterator::nextImpl(unsigned long) @ 0x0000000030a26001 12. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x0000000030a1f914 13. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:0: DB::ReadBufferIterator::next() @ 0x00000000309ffe24 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad6f75a 15. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad816d5 16. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000309eb787 17. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x0000000030a799ce 18. ./build_docker/./src/TableFunctions/TableFunctionObjectStorage.cpp:88: DB::TableFunctionObjectStorage::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fef67e5 19. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359da3a1 20. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359d76c5 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:07:37.765678 [ 2854 ] {210c8018-25dc-4bdb-a5f5-3c0bf92f3440} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): The table structure cannot be extracted from a TSV format file. You can specify the structure manually. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x0000000030f0115a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030f009a0 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000030efd200 9. ./build_docker/./src/Disks/ObjectStorages/ObjectStorageIteratorAsync.cpp:0: DB::IObjectStorageIteratorAsync::getCurrentBatchAndScheduleNext() @ 0x0000000030eff3d5 10. ./contrib/llvm-project/libcxx/include/optional:344: DB::StorageObjectStorageSource::GlobIterator::nextImplUnlocked(unsigned long) @ 0x0000000030a268ee 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:0: DB::StorageObjectStorageSource::GlobIterator::nextImpl(unsigned long) @ 0x0000000030a26001 12. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:468: DB::StorageObjectStorageSource::IIterator::next(unsigned long) @ 0x0000000030a1f914 13. ./build_docker/./src/Storages/ObjectStorage/ReadBufferIterator.cpp:0: DB::ReadBufferIterator::next() @ 0x00000000309ffe24 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad6f75a 15. ./src/Storages/ColumnsDescription.h:113: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad816d5 16. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000309eb787 17. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:0: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x0000000030a799ce 18. ./build_docker/./src/TableFunctions/TableFunctionObjectStorage.cpp:88: DB::TableFunctionObjectStorage::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fef67e5 19. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x00000000359da3a1 20. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x00000000359d76c5 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:07:38.198075 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:39.251012 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:40.272866 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:40.648154 [ 2854 ] {ff90bfde-3608-403f-95b9-f9d963ee278f} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55494) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038324ca2 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6c5a2 6. ./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&) @ 0x0000000034d531f4 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf7a3e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 10. ./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*) @ 0x000000003589fd91 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:07:40.649193 [ 2854 ] {ff90bfde-3608-403f-95b9-f9d963ee278f} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000038324ca2 5. ./src/Processors/QueryPlan/QueryPlan.h:53: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000034d6c5a2 6. ./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&) @ 0x0000000034d531f4 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf7a3e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 10. ./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*) @ 0x000000003589fd91 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:07:41.317461 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:41.956538 [ 12294 ] {37f6639a-ac6b-45a0-a3c6-1495376230ab} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35066) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:41.958849 [ 12294 ] {37f6639a-ac6b-45a0-a3c6-1495376230ab} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:42.393256 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:43.422413 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:44.172834 [ 12294 ] {0f3b7a0b-a4bd-468e-b169-46d923d44202} executeQuery: Code: 174. DB::Exception: Self referencing of `x` to `x`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55544) (comment: 01902_self_aliases_in_columns.sql) (in query: CREATE TABLE a (`number` UInt64, `x` MATERIALIZED x) ENGINE = MergeTree ORDER BY number SETTINGS index_granularity = 61010, min_bytes_for_wide_part = 970597983, ratio_of_defaults_for_sparse_serialization = 0.398435115814209, replace_long_file_name_to_hash = false, max_file_name_length = 39, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 166595702, compact_parts_max_granules_to_buffer = 168, compact_parts_merge_max_bytes_to_prefetch_part = 15020591, merge_max_block_size = 1480, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 12644954, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 70081, primary_key_compress_block_size = 27421), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:90: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003573230d 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035733bc8 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000035737d19 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 8. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000035637600 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563c8cb 10. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380e8989 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034896358 12. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 13. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:07:44.174174 [ 12294 ] {0f3b7a0b-a4bd-468e-b169-46d923d44202} TCPHandler: Code: 174. DB::Exception: Self referencing of `x` to `x`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:90: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003573230d 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035733bc8 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000035737d19 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 8. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000035637600 9. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563c8cb 10. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380e8989 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034896358 12. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 13. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:07:44.559263 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:45.339086 [ 12294 ] {ec0a30c1-6b2f-4102-972c-5a96173e43fd} executeQuery: Code: 174. DB::Exception: Self referencing of `j` to `j`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55544) (comment: 01902_self_aliases_in_columns.sql) (in query: CREATE TABLE foo (`i` Int32, `j` ALIAS j + 1) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 61010, min_bytes_for_wide_part = 970597983, ratio_of_defaults_for_sparse_serialization = 0.398435115814209, replace_long_file_name_to_hash = false, max_file_name_length = 39, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 166595702, compact_parts_max_granules_to_buffer = 168, compact_parts_merge_max_bytes_to_prefetch_part = 15020591, merge_max_block_size = 1480, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 12644954, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 70081, primary_key_compress_block_size = 27421), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:90: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003573230d 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035733bc8 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000035737d19 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 10. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000035637600 11. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563c8cb 12. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380e8989 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034896358 14. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 15. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 26. ? @ 0x00007f038ce47ac3 27. ? @ 0x00007f038ced9850 2025.03.31 19:07:45.340227 [ 12294 ] {ec0a30c1-6b2f-4102-972c-5a96173e43fd} TCPHandler: Code: 174. DB::Exception: Self referencing of `j` to `j`. Cyclic alias: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:90: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x000000003573230d 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035733bc8 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000035737d19 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 10. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000035637600 11. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563c8cb 12. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380e8989 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034896358 14. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 15. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 16. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 26. ? @ 0x00007f038ce47ac3 27. ? @ 0x00007f038ced9850 2025.03.31 19:07:45.687914 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:46.760866 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:47.282896 [ 12294 ] {22b4d2a5-def8-4424-8044-8da063fcee1a} executeQuery: Code: 57. DB::Exception: Table test_1.mt already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55622) (comment: 01293_optimize_final_force.sh) (in query: CREATE TABLE mt (`x` UInt8, `k` UInt8 DEFAULT 0) ENGINE = SummingMergeTree ORDER BY k SETTINGS index_granularity = 62787, min_bytes_for_wide_part = 1073741824, 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 = 0, compact_parts_max_bytes_to_buffer = 163848860, compact_parts_max_granules_to_buffer = 43, compact_parts_merge_max_bytes_to_prefetch_part = 30842084, merge_max_block_size = 143, 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 = 5597642022, index_granularity_bytes = 26109960, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 88867, primary_key_compress_block_size = 19049), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:47.284974 [ 12294 ] {22b4d2a5-def8-4424-8044-8da063fcee1a} TCPHandler: Code: 57. DB::Exception: Table test_1.mt 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:47.839429 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:48.935602 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:49.641319 [ 12294 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'min_compress_block_size' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./src/Common/Exception.h:0: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002fddfbfd 3. ./build_docker/./src/Access/SettingsConstraints.cpp:307: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595487 4. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 5. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 7. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 8. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:07:49.963563 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:50.183484 [ 12294 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'min_compress_block_size' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./src/Common/Exception.h:0: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002fddfbfd 3. ./build_docker/./src/Access/SettingsConstraints.cpp:307: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595487 4. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 5. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 7. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 8. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:07:50.813878 [ 12294 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'min_compress_block_size' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./src/Common/Exception.h:0: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x000000002fddfbfd 3. ./build_docker/./src/Access/SettingsConstraints.cpp:307: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595487 4. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 5. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315946f4 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 7. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 8. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:07:51.020183 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:52.085104 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:53.136281 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:53.222347 [ 12294 ] {832f0164-2d45-4ea8-8266-e0f51675f3f2} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35872) (comment: 00543_access_to_temporary_table_in_readonly_mode.sh) (in query: INSERT INTO test_readonly (ID) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e8f3f 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x00000000312e5c8a 5. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000003128fd83 6. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000337b6b02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000337265e3 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba3a5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:53.224323 [ 12294 ] {832f0164-2d45-4ea8-8266-e0f51675f3f2} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x00000000312e8f3f 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>, std::vector>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&, std::vector> const&) const @ 0x00000000312e5c8a 5. ./build_docker/./src/Access/ContextAccess.cpp:828: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>, std::vector> const&) const @ 0x000000003128fd83 6. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl>>(DB::AccessFlags const&, String const&, String const&, std::vector> const&) const @ 0x00000000337b6b02 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&, std::vector> const&) const @ 0x00000000337265e3 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba3a5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:54.276661 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:54.987425 [ 12294 ] {b92eb760-9468-4d86-bac7-b61838e95df2} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35908) (comment: 00543_access_to_temporary_table_in_readonly_mode.sh) (in query: DROP TABLE test_readonly;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 @ 0x00000000312dbad1 4. ./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 @ 0x00000000312d88aa 5. ./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 @ 0x000000003128f371 6. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x00000000337b5932 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x0000000033725e1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349284ea 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:07:54.990800 [ 12294 ] {b92eb760-9468-4d86-bac7-b61838e95df2} TCPHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 @ 0x00000000312dbad1 4. ./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 @ 0x00000000312d88aa 5. ./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 @ 0x000000003128f371 6. ./src/Access/ContextAccess.h:0: void DB::Context::checkAccessImpl(DB::AccessFlags const&, String const&, String const&) const @ 0x00000000337b5932 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::Context::checkAccess(DB::AccessFlags const&, DB::StorageID const&) const @ 0x0000000033725e1e 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349284ea 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:07:55.337251 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:55.541421 [ 12294 ] {42a0af3b-1e36-4dbb-9995-e36cd858d79d} executeQuery: Code: 57. DB::Exception: Table test_1.mt already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35962) (comment: 01293_optimize_final_force.sh) (in query: CREATE TABLE mt (`x` UInt8, `k` UInt8 DEFAULT 0) ENGINE = SummingMergeTree ORDER BY k SETTINGS index_granularity = 62787, min_bytes_for_wide_part = 1073741824, 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 = 0, compact_parts_max_bytes_to_buffer = 163848860, compact_parts_max_granules_to_buffer = 43, compact_parts_merge_max_bytes_to_prefetch_part = 30842084, merge_max_block_size = 143, 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 = 5597642022, index_granularity_bytes = 26109960, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 88867, primary_key_compress_block_size = 19049), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:55.543753 [ 12294 ] {42a0af3b-1e36-4dbb-9995-e36cd858d79d} TCPHandler: Code: 57. DB::Exception: Table test_1.mt 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:07:56.456494 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:57.539932 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:58.646615 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:07:59.691603 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:00.745032 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:01.426301 [ 12294 ] {a862b234-a804-4673-b4d5-3a5bbe3b8766} executeQuery: Code: 57. DB::Exception: Table test_1.mt already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:43704) (comment: 01293_optimize_final_force.sh) (in query: CREATE TABLE mt (`x` UInt8, `k` UInt8 DEFAULT 0) ENGINE = SummingMergeTree ORDER BY k SETTINGS index_granularity = 62787, min_bytes_for_wide_part = 1073741824, 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 = 0, compact_parts_max_bytes_to_buffer = 163848860, compact_parts_max_granules_to_buffer = 43, compact_parts_merge_max_bytes_to_prefetch_part = 30842084, merge_max_block_size = 143, 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 = 5597642022, index_granularity_bytes = 26109960, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 88867, primary_key_compress_block_size = 19049), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:08:01.428082 [ 12294 ] {a862b234-a804-4673-b4d5-3a5bbe3b8766} TCPHandler: Code: 57. DB::Exception: Table test_1.mt 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:08:01.782917 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:02.830397 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:02.963472 [ 3702 ] {} test_1.mt (233ca5eb-8a78-4585-ac80-92d958e24e48): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.03.31 19:08:02.964660 [ 3702 ] {} DatabaseCatalog: Cannot drop table test_1.mt (233ca5eb-8a78-4585-ac80-92d958e24e48). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 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>*) @ 0x00000000397276a1 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>*) @ 0x0000000039720472 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2997: DB::MergeTreeData::dropAllData() @ 0x0000000039736baa 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2cda53 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339b9fe2 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339daaa3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303ec68c 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()() @ 0x00000000303ec46d 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b123d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303eeb6e 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:03.970035 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:04.635928 [ 12294 ] {f43933d9-4fd0-45c7-bfe6-e3b6ffbb0f7e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:43758) (comment: 00926_adaptive_index_granularity_merge_tree.sql) (in query: SELECT '-----';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:08:04.638326 [ 12294 ] {f43933d9-4fd0-45c7-bfe6-e3b6ffbb0f7e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:08:05.009632 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:06.177327 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:07.264750 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:08.288482 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:09.444547 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:10.476262 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:11.562559 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:12.616835 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:13.685242 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:14.725197 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:15.620451 [ 4240 ] {f830c558-ab7a-4331-8213-358330d3cd2d} executeQuery: Code: 183. DB::Exception: arrayJoin is not allowed in mutations. (UNEXPECTED_EXPRESSION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52650) (comment: 02504_disallow_arrayjoin_in_mutations.sql) (in query: ALTER TABLE test_02504 UPDATE b = 33 WHERE arrayJoin([1, 2]) = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1286: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f92018 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::validate() @ 0x0000000034f9b45a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854d3c 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:08:15.621692 [ 4240 ] {f830c558-ab7a-4331-8213-358330d3cd2d} TCPHandler: Code: 183. DB::Exception: arrayJoin is not allowed in mutations. (UNEXPECTED_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1286: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f92018 5. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::validate() @ 0x0000000034f9b45a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854d3c 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:08:15.836887 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:16.944639 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:17.988012 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:19.171913 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:20.000389 [ 4240 ] {cf175f4a-e6c3-4153-9a72-ac598d9eb586} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int8 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toInt8(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt8(0) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec688 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:20.002056 [ 4240 ] {cf175f4a-e6c3-4153-9a72-ac598d9eb586} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int8 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toInt8(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec688 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:20.478118 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:21.560250 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:21.748502 [ 4240 ] {3aa0c173-2754-43ce-97f7-31e26edb0734} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope SELECT toInt8(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt8(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:21.749908 [ 4240 ] {3aa0c173-2754-43ce-97f7-31e26edb0734} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int8, Date) of function greater: In scope SELECT toInt8(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:22.621473 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:23.289683 [ 4240 ] {1fdb7fca-a3fa-4cba-aa3a-5e9d1f76ddfb} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int8, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:23.291189 [ 4240 ] {1fdb7fca-a3fa-4cba-aa3a-5e9d1f76ddfb} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int8, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:23.668338 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:24.119046 [ 4240 ] {a328ae75-b17c-46ef-9473-359c3e4f54c0} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int16 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toInt16(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt16(0) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec688 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:24.120355 [ 4240 ] {a328ae75-b17c-46ef-9473-359c3e4f54c0} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int16 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toInt16(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec688 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:24.275979 [ 4240 ] {121f4322-e25b-4edf-a2e4-833cb70ee460} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope SELECT toInt16(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt16(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:24.277289 [ 4240 ] {121f4322-e25b-4edf-a2e4-833cb70ee460} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int16, Date) of function greater: In scope SELECT toInt16(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:24.313598 [ 4240 ] {4bb695a9-4888-4d46-af87-7c50824497cf} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int16, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:24.315372 [ 4240 ] {4bb695a9-4888-4d46-af87-7c50824497cf} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int16, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:24.519022 [ 12294 ] {4ade1935-c514-450b-b805-18b99c20d97a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42374) (comment: 03049_unknown_identifier_materialized_column.sql) (in query: DROP DATABASE IF EXISTS test_xqe8mxqi), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:24.521018 [ 12294 ] {4ade1935-c514-450b-b805-18b99c20d97a} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:24.606683 [ 12294 ] {2ffec71d-0300-4a8e-9196-8061fdcdc297} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58360) (comment: 03049_unknown_identifier_materialized_column.sql) (in query: DROP DATABASE IF EXISTS test_xqe8mxqi ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:24.608696 [ 12294 ] {2ffec71d-0300-4a8e-9196-8061fdcdc297} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:24.632083 [ 12293 ] {53b3c167-8943-420d-bc99-3810c513602e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58374) (comment: 03049_unknown_identifier_materialized_column.sql) (in query: DROP DATABASE IF EXISTS test_xqe8mxqi ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:24.634320 [ 12293 ] {53b3c167-8943-420d-bc99-3810c513602e} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:24.649358 [ 2854 ] {c23fcebb-f0ee-4010-b9d7-92d215d0c813} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58376) (comment: 03049_unknown_identifier_materialized_column.sql) (in query: DROP DATABASE IF EXISTS test_xqe8mxqi ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:24.651432 [ 2854 ] {c23fcebb-f0ee-4010-b9d7-92d215d0c813} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:24.666007 [ 12294 ] {a1ccd00e-620a-4063-ac2b-accad0c25e40} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58382) (comment: 03049_unknown_identifier_materialized_column.sql) (in query: DROP DATABASE IF EXISTS test_xqe8mxqi ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:24.668031 [ 12294 ] {a1ccd00e-620a-4063-ac2b-accad0c25e40} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:24.683332 [ 2854 ] {6f9a0ba7-fa99-461c-9606-a04620441a1a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58392) (comment: 03049_unknown_identifier_materialized_column.sql) (in query: DROP DATABASE IF EXISTS test_xqe8mxqi ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:24.685344 [ 2854 ] {6f9a0ba7-fa99-461c-9606-a04620441a1a} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:24.819984 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:25.176828 [ 4240 ] {da923233-9f8f-4e64-8006-b769cb8938d1} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int32 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toInt32(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt32(0) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec688 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:25.178291 [ 4240 ] {da923233-9f8f-4e64-8006-b769cb8938d1} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int32 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toInt32(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec688 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:25.360448 [ 4240 ] {342004c0-292e-465c-998e-b72a0b45dbcd} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope SELECT toInt32(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt32(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:25.361518 [ 4240 ] {342004c0-292e-465c-998e-b72a0b45dbcd} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int32, Date) of function greater: In scope SELECT toInt32(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:25.391050 [ 4240 ] {29656c0c-54f3-4204-8617-bd587de97138} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int32, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:25.392398 [ 4240 ] {29656c0c-54f3-4204-8617-bd587de97138} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int32, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:25.887023 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:25.911240 [ 2854 ] {7ea6d68a-40db-482d-b0da-f07187ab9cc7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42392) (comment: 03049_unknown_identifier_materialized_column.sql) (in query: DROP DATABASE IF EXISTS test_sno510ek), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:25.913038 [ 2854 ] {7ea6d68a-40db-482d-b0da-f07187ab9cc7} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:26.115341 [ 12294 ] {7d4ddb1f-e199-4a5d-9eab-52fc9f6215c2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58432) (comment: 03049_unknown_identifier_materialized_column.sql) (in query: DROP DATABASE IF EXISTS test_sno510ek ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:26.117616 [ 12294 ] {7d4ddb1f-e199-4a5d-9eab-52fc9f6215c2} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:26.192872 [ 12293 ] {ca2e9791-f32d-4817-9dc3-e908449a9f5f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58436) (comment: 03049_unknown_identifier_materialized_column.sql) (in query: DROP DATABASE IF EXISTS test_sno510ek ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:26.195072 [ 12293 ] {ca2e9791-f32d-4817-9dc3-e908449a9f5f} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:26.209231 [ 2854 ] {0146afa2-9716-4ace-beed-ea44b6a9badf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58446) (comment: 03049_unknown_identifier_materialized_column.sql) (in query: DROP DATABASE IF EXISTS test_sno510ek ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:26.212430 [ 2854 ] {0146afa2-9716-4ace-beed-ea44b6a9badf} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:26.354117 [ 4240 ] {da9fe4eb-e966-41c8-b4e2-ea1c5f27fff8} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt64, Int64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toInt64(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt64(0) AS x, toUInt64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec688 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:26.355629 [ 4240 ] {da9fe4eb-e966-41c8-b4e2-ea1c5f27fff8} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt64, Int64 because some of them are signed integers and some are unsigned integers, but there is no signed integer type, that can exactly represent all required unsigned integer values: In scope SELECT toInt64(0) AS x, toUInt64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:155: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec688 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:27.026371 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:28.114966 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:28.188951 [ 4240 ] {8297aa59-910c-4262-ba9e-d6a0a026366a} executeQuery: Code: 386. DB::Exception: There is no supertype for types Float32, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toInt64(0) AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt64(0) AS x, toFloat32(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:88: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec6c7 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:28.190276 [ 4240 ] {8297aa59-910c-4262-ba9e-d6a0a026366a} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Float32, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toInt64(0) AS x, toFloat32(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:88: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec6c7 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:28.251817 [ 4240 ] {be71585c-5032-46ff-8577-09855846af81} executeQuery: Code: 386. DB::Exception: There is no supertype for types Float64, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toInt64(0) AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt64(0) AS x, toFloat64(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:88: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec6c7 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:28.253197 [ 4240 ] {be71585c-5032-46ff-8577-09855846af81} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Float64, Int64 because some of them are integers and some are floating point, but there is no floating point type, that can exactly represent all required integers: In scope SELECT toInt64(0) AS x, toFloat64(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::unordered_set, std::equal_to, std::allocator>>(std::unordered_set, std::equal_to, std::allocator> const&, std::basic_string_view>, int) @ 0x00000000325ecba2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:88: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x00000000325ec6c7 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:650: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f77cb 6. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 8. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:28.286256 [ 4240 ] {1a0a0b80-f175-47a4-9502-fd4f7d68fa7b} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope SELECT toInt64(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt64(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:28.287468 [ 4240 ] {1a0a0b80-f175-47a4-9502-fd4f7d68fa7b} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (Int64, Date) of function greater: In scope SELECT toInt64(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:28.328832 [ 4240 ] {689d7e80-68d9-4301-92e8-9e1772684838} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int64, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt64(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toInt64(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:28.330395 [ 4240 ] {689d7e80-68d9-4301-92e8-9e1772684838} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int64, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toInt64(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:28.970692 [ 3609 ] {74b4b1f9-f5de-490e-9f22-b0c92da782b2::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:28.971261 [ 3609 ] {74b4b1f9-f5de-490e-9f22-b0c92da782b2::all_1_1_0_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:29.185345 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:29.436308 [ 4240 ] {53a0e933-44fd-4edb-9156-d45525558f1f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope SELECT toUInt8(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toUInt8(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:29.437401 [ 4240 ] {53a0e933-44fd-4edb-9156-d45525558f1f} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt8, Date) of function greater: In scope SELECT toUInt8(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:29.468458 [ 4240 ] {cb14afd9-b3be-4416-99c2-21ecb7f325ba} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toUInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:29.477844 [ 4240 ] {cb14afd9-b3be-4416-99c2-21ecb7f325ba} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt8(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:29.490315 [ 3600 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f7684ad4-5a51-47e0-b9af-e4cdeab38f3a::202503_1_76_18}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:29.796754 [ 3830 ] {9edff3d8-42ff-4554-8ca5-3c2b64ef5bac} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42440) (comment: 02565_update_empty_nested.sql) (in query: ALTER TABLE t_update_empty_nested UPDATE `nested.arr2` = `nested.arr1` 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfc29f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfc005 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:29.798965 [ 3830 ] {9edff3d8-42ff-4554-8ca5-3c2b64ef5bac} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfc29f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfc005 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:30.239149 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:30.629487 [ 4240 ] {d9164381-a767-4504-b501-61743e741dfc} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope SELECT toUInt16(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toUInt16(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:30.630986 [ 4240 ] {d9164381-a767-4504-b501-61743e741dfc} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt16, Date) of function greater: In scope SELECT toUInt16(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:30.659645 [ 4240 ] {d8189914-e328-4e19-9f8d-9993506228af} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt16, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toUInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:30.660812 [ 4240 ] {d8189914-e328-4e19-9f8d-9993506228af} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt16, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt16(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:31.323453 [ 4240 ] {dcd82d04-4cd4-411d-a2d6-734b20842fec} executeQuery: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope SELECT toUInt32(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toUInt32(0) AS x, toDate(1) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:31.324646 [ 4240 ] {dcd82d04-4cd4-411d-a2d6-734b20842fec} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments (UInt32, Date) of function greater: In scope SELECT toUInt32(0) AS x, toDate(1) AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionComparison::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000ff0da70 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./contrib/llvm-project/libcxx/include/vector:438: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348c525 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:08:31.356440 [ 4240 ] {34530ea4-05c5-4aba-97f6-7d1732f89858} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt32, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toUInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:31.357701 [ 4240 ] {34530ea4-05c5-4aba-97f6-7d1732f89858} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt32, DateTime('Asia/Istanbul') because some of them are Date/Date32/DateTime/DateTime64 and some of them are not: In scope SELECT toUInt32(0) AS x, toDateTime(1, 'Asia/Istanbul') AS y, if(x > y, x, y) AS z, toTypeName(x), toTypeName(y), toTypeName(z). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x00000000325ea0e2 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x00000000325f928c 5. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000125d7c15 6. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 7. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 8. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 9. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 10. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 12. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 15. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 31. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 2025.03.31 19:08:31.470217 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:31.636356 [ 4240 ] {e49265e1-b9ed-4758-8c1f-ad4076c9e1f2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52688) (comment: 00735_long_conditional.sql) (in query: SELECT toUInt32(0) AS x, toDecimal128(1, 0) AS y, ((x > y) ? x : y) AS z, toTypeName(x), toTypeName(y), toTypeName(z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:08:31.637624 [ 4240 ] {e49265e1-b9ed-4758-8c1f-ad4076c9e1f2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:08:32.536570 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:33.105503 [ 12294 ] {db370896-0eab-4c08-ae95-ea1f1b740130} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual UInt64: In scope SELECT number.1 FROM numbers(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33498) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(number, 1) FROM numbers(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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c938938 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:08:33.107039 [ 12294 ] {db370896-0eab-4c08-ae95-ea1f1b740130} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual UInt64: In scope SELECT number.1 FROM numbers(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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c938938 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:08:33.363080 [ 12293 ] {f30e5580-4315-49a6-90a5-a9ad73caca4b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33524) (comment: 01115_join_with_dictionary.sql) (in query: CREATE TABLE t1 (`key` UInt64, `a` UInt8, `b` String, `c` Float64) ENGINE = MergeTree ORDER BY key SETTINGS index_granularity = 364, 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 = 536870912, compact_parts_max_bytes_to_buffer = 34860117, compact_parts_max_granules_to_buffer = 255, compact_parts_merge_max_bytes_to_prefetch_part = 2493119, merge_max_block_size = 20437, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7223615261, index_granularity_bytes = 17086800, concurrent_part_removal_threshold = 73, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 80484, primary_key_compress_block_size = 87812), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 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>) @ 0x000000003a2c1d8a 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>&&) @ 0x000000003a2bfe8f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:08:33.365321 [ 12293 ] {f30e5580-4315-49a6-90a5-a9ad73caca4b} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 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>) @ 0x000000003a2c1d8a 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>&&) @ 0x000000003a2bfe8f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:08:33.569834 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:34.701057 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:34.902893 [ 12294 ] {38959181-40bb-4577-8974-3dbbcdb538bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t1) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33498) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000009e5c54d 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c938b26 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:08:34.904073 [ 12294 ] {38959181-40bb-4577-8974-3dbbcdb538bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t1) FROM t_tuple_element. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000009e5c54d 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c938b26 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:08:35.739150 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:36.605462 [ 12294 ] {48028e9b-408f-4525-8f9d-f1a5f95f223a} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with name 'b': In scope SELECT tupleElement(t1, 'b') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33498) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, 'b') FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939d00 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:36.606885 [ 12294 ] {48028e9b-408f-4525-8f9d-f1a5f95f223a} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with name 'b': In scope SELECT tupleElement(t1, 'b') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939d00 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:36.884160 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:37.994457 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:38.394514 [ 12294 ] {4f0d8edd-7977-46d7-adf5-d7cf676faf1a} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t1.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33498) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, 0) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46068a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939b33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:38.395763 [ 12294 ] {4f0d8edd-7977-46d7-adf5-d7cf676faf1a} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t1.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46068a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939b33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:38.410039 [ 12294 ] {c65a8e8e-6c70-4977-9008-6697801bd33e} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t1.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33498) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, 3) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46068a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939b33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:38.411209 [ 12294 ] {c65a8e8e-6c70-4977-9008-6697801bd33e} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t1.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46068a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939b33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:39.085201 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:40.133146 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:40.276457 [ 12294 ] {8a4d41e8-dd4e-49ba-88da-de9f31921e57} executeQuery: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33498) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c9399b7 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:40.316697 [ 12294 ] {8a4d41e8-dd4e-49ba-88da-de9f31921e57} TCPHandler: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c9399b7 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:40.778445 [ 12294 ] {13442477-35b0-4ddd-a4be-06127aaf6ea8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t2) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33498) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000009e5c54d 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c938b26 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:08:40.779757 [ 12294 ] {13442477-35b0-4ddd-a4be-06127aaf6ea8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t2) FROM t_tuple_element. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x0000000009e5c54d 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c938b26 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:08:40.795834 [ 12294 ] {2fb096c8-2ded-4da2-ba86-09bb904e4880} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with name 'a': In scope SELECT tupleElement(t2, 'a') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33498) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, 'a') FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939d00 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:40.797193 [ 12294 ] {2fb096c8-2ded-4da2-ba86-09bb904e4880} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with name 'a': In scope SELECT tupleElement(t2, 'a') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939d00 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:40.812105 [ 12294 ] {be5eaaba-7c70-41ba-9560-98ada68bcb90} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t2.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33498) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, 0) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46068a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939b33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:40.813517 [ 12294 ] {be5eaaba-7c70-41ba-9560-98ada68bcb90} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t2.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46068a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939b33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:40.827590 [ 12294 ] {507c6385-70aa-4e38-9730-63f36e29b411} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t2.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33498) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, 3) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46068a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939b33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:40.828668 [ 12294 ] {507c6385-70aa-4e38-9730-63f36e29b411} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t2.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000b46068a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c939b33 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:40.890181 [ 12294 ] {ffae27c5-6a1e-47b3-a147-a8ba5a4041c1} executeQuery: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33498) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c9399b7 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:40.891262 [ 12294 ] {ffae27c5-6a1e-47b3-a147-a8ba5a4041c1} TCPHandler: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001c9399b7 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c937f92 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:08:41.196431 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:42.318546 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:42.787535 [ 3158 ] {} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339b83d8 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339b942e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339da35f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 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*) @ 0x00000000319a464f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:43.366797 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:44.212951 [ 3830 ] {0defd78a-0899-4603-8d41-736b4a1d4415} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35518) (comment: 01277_buffer_column_order.sql) (in query: drop table buffer_01277;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:08:44.214834 [ 3830 ] {0defd78a-0899-4603-8d41-736b4a1d4415} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:08:44.338872 [ 3830 ] {548cf7d8-37e3-43fd-9fb9-3dca76db49c6} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44658) (comment: 01277_buffer_column_order.sql) (in query: DROP DATABASE IF EXISTS test_kj1kezzc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:44.340977 [ 3830 ] {548cf7d8-37e3-43fd-9fb9-3dca76db49c6} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:44.545431 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:45.537384 [ 12293 ] {70bc91f2-ea01-4935-9070-f25b293a171a} executeQuery: Code: 57. DB::Exception: Table test_t03tp7rv.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35556) (comment: 01097_one_more_range_reader_test.sql) (in query: CREATE TABLE t (`id` UInt32, `a` Int) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 4529, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 75, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 450975121, compact_parts_max_granules_to_buffer = 3, compact_parts_merge_max_bytes_to_prefetch_part = 16104733, merge_max_block_size = 23253, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 838170, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4985606313, index_granularity_bytes = 9778202, concurrent_part_removal_threshold = 53, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 72559, primary_key_compress_block_size = 64480), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:08:45.539315 [ 12293 ] {70bc91f2-ea01-4935-9070-f25b293a171a} TCPHandler: Code: 57. DB::Exception: Table test_t03tp7rv.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:08:45.655877 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:46.715331 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:47.794763 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:48.969541 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:50.071787 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:51.089581 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:52.208277 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:53.305193 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:54.331130 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:55.379210 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:56.408225 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:57.433362 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:57.989498 [ 12293 ] {cda3a702-5f38-4b7b-be92-53d5392bd22b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=8): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35620) (comment: 02841_parallel_final_wrong_columns_order.sql) (in query: select count() from tab2 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ce71b2 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&) @ 0x0000000039ce966a 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 @ 0x0000000032630982 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263138d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce0b44 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) @ 0x0000000039ce0469 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&) @ 0x000000003999ab28 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 @ 0x000000003998fbb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c03fa33 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf9e973 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 2025.03.31 19:08:57.997773 [ 12293 ] {cda3a702-5f38-4b7b-be92-53d5392bd22b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=8): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ce71b2 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&) @ 0x0000000039ce966a 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 @ 0x0000000032630982 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263138d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce0b44 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) @ 0x0000000039ce0469 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&) @ 0x000000003999ab28 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 @ 0x000000003998fbb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c03fa33 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf9e973 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 30. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 2025.03.31 19:08:58.206695 [ 4240 ] {5bdc1d54-581c-4849-abdc-bfc9b9afd255} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50604) (comment: 02841_parallel_final_wrong_columns_order.sql) (in query: DROP DATABASE IF EXISTS test_ktia8rnf ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:58.208548 [ 4240 ] {5bdc1d54-581c-4849-abdc-bfc9b9afd255} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:58.221493 [ 2854 ] {cc981cf9-75ec-418a-839b-97e14d636939} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50610) (comment: 02841_parallel_final_wrong_columns_order.sql) (in query: DROP DATABASE IF EXISTS test_ktia8rnf ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:58.304644 [ 2854 ] {cc981cf9-75ec-418a-839b-97e14d636939} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:58.319335 [ 4187 ] {27382f22-941d-4e73-a773-96c6819b1ec3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50620) (comment: 02841_parallel_final_wrong_columns_order.sql) (in query: DROP DATABASE IF EXISTS test_ktia8rnf ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:58.321347 [ 4187 ] {27382f22-941d-4e73-a773-96c6819b1ec3} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:58.335499 [ 12293 ] {fd35095c-c4f5-4313-899d-4c8633cdf6e4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50636) (comment: 02841_parallel_final_wrong_columns_order.sql) (in query: DROP DATABASE IF EXISTS test_ktia8rnf ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:08:58.337596 [ 12293 ] {fd35095c-c4f5-4313-899d-4c8633cdf6e4} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:08:58.529185 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:59.504559 [ 2854 ] {5675b1bc-b85d-420c-acac-376f2b525ec4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42248) (comment: 00502_sum_map.sql) (in query: SELECT sumMapMerge(s) FROM (SELECT sumMapState(statusMap.status, statusMap.requests) AS s FROM sum_map);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:08:59.538478 [ 2854 ] {5675b1bc-b85d-420c-acac-376f2b525ec4} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:08:59.581957 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:08:59.643334 [ 4187 ] {54139e02-edec-48ee-8888-67e12ff430fa} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:34346) (comment: 00502_sum_map.sql) (in query: DROP DATABASE IF EXISTS test_ms4ov7pm ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:08:59.644985 [ 4187 ] {54139e02-edec-48ee-8888-67e12ff430fa} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:00.606580 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:01.626896 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:02.471064 [ 2854 ] {f587a71b-5a00-4cae-985b-6d55c454f57f} executeQuery: Code: 264. DB::Exception: Table 'test_in3pvoe0.testJoinTable (218ab98f-f322-4135-bca0-ced5a3b9b70a)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58392) (comment: 01050_engine_join_crash.sql) (in query: SELECT * FROM (SELECT * FROM numbers(10)) js1 INNER JOIN testJoinTable USING number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Storages/StorageJoin.cpp:235: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fa185 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd3b4c 6. ./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&) @ 0x0000000034d81425 7. ./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&) @ 0x0000000034d568d7 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf7a3e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 11. ./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*) @ 0x000000003589fd91 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:09:02.472247 [ 2854 ] {f587a71b-5a00-4cae-985b-6d55c454f57f} TCPHandler: Code: 264. DB::Exception: Table 'test_in3pvoe0.testJoinTable (218ab98f-f322-4135-bca0-ced5a3b9b70a)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Storages/StorageJoin.cpp:235: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x00000000383fa185 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd3b4c 6. ./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&) @ 0x0000000034d81425 7. ./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&) @ 0x0000000034d568d7 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf7a3e 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 11. ./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*) @ 0x000000003589fd91 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:09:02.607877 [ 2854 ] {ae222c32-1929-4ef3-a4a6-bd28c3bfa9f8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58392) (comment: 01050_engine_join_crash.sql) (in query: SELECT * FROM (SELECT * FROM numbers(10)) js1 INNER JOIN (SELECT * FROM testJoinTable) js2 USING number ORDER BY number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:02.610998 [ 2854 ] {ae222c32-1929-4ef3-a4a6-bd28c3bfa9f8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:02.826488 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:03.996691 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:05.081483 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:06.213621 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:06.521692 [ 12294 ] {f2617fd3-a4a6-4ed2-91cd-3fbfb302ed5e} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58564) (comment: 00875_join_right_nulls.sql) (in query: CREATE TABLE t (x String) ENGINE = Log();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:06.523557 [ 12294 ] {f2617fd3-a4a6-4ed2-91cd-3fbfb302ed5e} TCPHandler: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:07.253995 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:08.275128 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:09.148636 [ 12294 ] {e47ee593-8176-4456-9a06-17421e29932e} executeQuery: Code: 57. DB::Exception: Table test_1.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58592) (comment: 01034_JSONCompactEachRow.sql) (in query: CREATE TABLE test_table (`v1` String, `v2` UInt8, `v3` DEFAULT v2 * 16, `v4` UInt8 DEFAULT 8) ENGINE = MergeTree ORDER BY v2 SETTINGS index_granularity = 18657, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 246896028, compact_parts_max_bytes_to_buffer = 16345180, compact_parts_max_granules_to_buffer = 13, compact_parts_merge_max_bytes_to_prefetch_part = 16732637, merge_max_block_size = 94, old_parts_lifetime = 136., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10190532698, index_granularity_bytes = 17213863, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 64424, primary_key_compress_block_size = 55815), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:09.151070 [ 12294 ] {e47ee593-8176-4456-9a06-17421e29932e} TCPHandler: Code: 57. DB::Exception: Table test_1.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:09.311213 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:10.441238 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:11.015745 [ 12294 ] {a06f8045-6287-4715-8445-cf978f640f4a} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n3 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:49478) (comment: 01851_clear_column_referenced_by_mv.sql) (in query: ALTER TABLE `01851_merge_tree` DROP COLUMN n3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039756e11 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:11.017068 [ 12294 ] {a06f8045-6287-4715-8445-cf978f640f4a} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n3 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039756e11 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:11.037111 [ 12294 ] {f7dd04bd-1e9b-4c95-aba7-d686b99ac706} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:49478) (comment: 01851_clear_column_referenced_by_mv.sql) (in query: ALTER TABLE `01851_merge_tree` DROP COLUMN n2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039756e11 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:11.038115 [ 12294 ] {f7dd04bd-1e9b-4c95-aba7-d686b99ac706} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000039756e11 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:11.467367 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:12.535019 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:12.552185 [ 12293 ] {cbc57593-5b7f-411b-bb6b-6296695abf51} executeQuery: Code: 36. DB::Exception: Second cell (id 9223372036854775806) is not valid in function s2CellsIntersect: In scope SELECT s2CellsIntersect(9926595209846587392, 9223372036854775806). (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:49498) (comment: 01853_s2_cells_intersect.sql) (in query: SELECT s2CellsIntersect(9926595209846587392, 9223372036854775806);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000f94326d 4. DB::(anonymous namespace)::FunctionS2CellsIntersect::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bee502a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:09:12.553648 [ 12293 ] {cbc57593-5b7f-411b-bb6b-6296695abf51} TCPHandler: Code: 36. DB::Exception: Second cell (id 9223372036854775806) is not valid in function s2CellsIntersect: In scope SELECT s2CellsIntersect(9926595209846587392, 9223372036854775806). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000f94326d 4. DB::(anonymous namespace)::FunctionS2CellsIntersect::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001bee502a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:09:13.594845 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:14.692233 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:15.799780 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:16.833195 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:17.903469 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:18.947753 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:19.805579 [ 3722 ] {} ExternalDictionariesLoader: Could not check if external dictionary '57f9bb0f-f990-41f9-adb7-59869240f571' was modified: Code: 60. DB::Exception: Unknown table expression identifier 'dict_invalidate' in scope SELECT max(last_time) FROM dict_invalidate. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa04d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334db18a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033426e8d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:195: DB::ClickHouseDictionarySource::doInvalidateQuery(String const&) const @ 0x0000000020b1a98f 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:0: DB::ClickHouseDictionarySource::isModified() const @ 0x0000000020b18739 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::isModified() const @ 0x0000000020d47010 19. ./build_docker/./src/Interpreters/ExternalLoader.cpp:669: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x00000000347de1f0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x00000000347dcf23 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347e4126 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347e3edf 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:20.142465 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:21.189002 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:22.316628 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:23.368826 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:24.541519 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:24.825982 [ 3722 ] {} ExternalDictionariesLoader: Could not check if external dictionary '57f9bb0f-f990-41f9-adb7-59869240f571' was modified: Code: 60. DB::Exception: Unknown table expression identifier 'dict_invalidate' in scope SELECT max(last_time) FROM dict_invalidate. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa04d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334db18a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033426e8d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:195: DB::ClickHouseDictionarySource::doInvalidateQuery(String const&) const @ 0x0000000020b1a98f 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:0: DB::ClickHouseDictionarySource::isModified() const @ 0x0000000020b18739 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::isModified() const @ 0x0000000020d47010 19. ./build_docker/./src/Interpreters/ExternalLoader.cpp:669: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x00000000347de1f0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x00000000347dcf23 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347e4126 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347e3edf 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:25.620473 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:26.748863 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:27.808322 [ 4240 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:32988, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204ba910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204bb8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e374d 6. DB::ReadBuffer::next() @ 0x00000000095afaaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003ab92e9e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:27.924082 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:29.033445 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:29.238992 [ 4240 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:33058, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204ba910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204bb8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e374d 6. DB::ReadBuffer::next() @ 0x00000000095afaaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003ab92e9e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:29.833992 [ 3722 ] {} ExternalDictionariesLoader: Could not check if external dictionary '57f9bb0f-f990-41f9-adb7-59869240f571' was modified: Code: 60. DB::Exception: Unknown table expression identifier 'dict_invalidate' in scope SELECT max(last_time) FROM dict_invalidate. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa04d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334db18a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033426e8d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:195: DB::ClickHouseDictionarySource::doInvalidateQuery(String const&) const @ 0x0000000020b1a98f 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:0: DB::ClickHouseDictionarySource::isModified() const @ 0x0000000020b18739 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::isModified() const @ 0x0000000020d47010 19. ./build_docker/./src/Interpreters/ExternalLoader.cpp:669: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x00000000347de1f0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x00000000347dcf23 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347e4126 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347e3edf 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:30.150301 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:31.246509 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:32.289203 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:32.606854 [ 2854 ] {c2e0b06c-4240-4e08-ab70-ca9a7f7d58fc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42224) (comment: 00653_verification_monotonic_data_load.sh) (in query: SELECT count() FROM unsigned_integer_test_table WHERE toUInt64(val) == 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:32.669026 [ 2854 ] {c2e0b06c-4240-4e08-ab70-ca9a7f7d58fc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:33.347215 [ 2854 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:42242, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204ba910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204bb8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e374d 6. DB::ReadBuffer::next() @ 0x00000000095afaaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003ab92e9e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:33.359730 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:34.110502 [ 3596 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fce196b8-b32c-4319-8cdf-3d340eb025b8::202503_131_184_10}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:34.432059 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:34.841209 [ 3722 ] {} ExternalDictionariesLoader: Could not check if external dictionary '57f9bb0f-f990-41f9-adb7-59869240f571' was modified: Code: 60. DB::Exception: Unknown table expression identifier 'dict_invalidate' in scope SELECT max(last_time) FROM dict_invalidate. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa04d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334db18a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033426e8d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:195: DB::ClickHouseDictionarySource::doInvalidateQuery(String const&) const @ 0x0000000020b1a98f 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:0: DB::ClickHouseDictionarySource::isModified() const @ 0x0000000020b18739 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::isModified() const @ 0x0000000020d47010 19. ./build_docker/./src/Interpreters/ExternalLoader.cpp:669: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x00000000347de1f0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x00000000347dcf23 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347e4126 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347e3edf 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:35.538343 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:36.570374 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:36.935852 [ 4240 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:42352, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204ba910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204bb8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e374d 6. DB::ReadBuffer::next() @ 0x00000000095afaaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003ab92e9e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:37.712076 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:38.622877 [ 2854 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:42388, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204ba910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204bb8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e374d 6. DB::ReadBuffer::next() @ 0x00000000095afaaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003ab92e9e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:38.744424 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:39.161249 [ 4240 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:42414, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204ba910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204bb8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e374d 6. DB::ReadBuffer::next() @ 0x00000000095afaaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003ab92e9e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:39.814874 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:39.848111 [ 3722 ] {} ExternalDictionariesLoader: Could not check if external dictionary '57f9bb0f-f990-41f9-adb7-59869240f571' was modified: Code: 60. DB::Exception: Unknown table expression identifier 'dict_invalidate' in scope SELECT max(last_time) FROM dict_invalidate. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa04d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334db18a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033426e8d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:195: DB::ClickHouseDictionarySource::doInvalidateQuery(String const&) const @ 0x0000000020b1a98f 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:0: DB::ClickHouseDictionarySource::isModified() const @ 0x0000000020b18739 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::isModified() const @ 0x0000000020d47010 19. ./build_docker/./src/Interpreters/ExternalLoader.cpp:669: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x00000000347de1f0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x00000000347dcf23 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347e4126 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347e3edf 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:40.899971 [ 4240 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:40730, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204ba910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204bb8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e374d 6. DB::ReadBuffer::next() @ 0x00000000095afaaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003ab92e9e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:40.926695 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:41.990808 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:43.049582 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:44.129410 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:44.855594 [ 3722 ] {} ExternalDictionariesLoader: Could not check if external dictionary '57f9bb0f-f990-41f9-adb7-59869240f571' was modified: Code: 60. DB::Exception: Unknown table expression identifier 'dict_invalidate' in scope SELECT max(last_time) FROM dict_invalidate. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa04d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334db18a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033426e8d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:195: DB::ClickHouseDictionarySource::doInvalidateQuery(String const&) const @ 0x0000000020b1a98f 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:0: DB::ClickHouseDictionarySource::isModified() const @ 0x0000000020b18739 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::isModified() const @ 0x0000000020d47010 19. ./build_docker/./src/Interpreters/ExternalLoader.cpp:669: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x00000000347de1f0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x00000000347dcf23 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347e4126 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347e3edf 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:45.241008 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:46.373019 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:47.481927 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:48.514795 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:49.642904 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:49.680312 [ 15299 ] {3f69a250-dee3-4709-939e-0733c656c853} executeQuery: Code: 57. DB::Exception: Table test_e21kt9ba.dict_invalidate already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38814) (comment: 01040_dictionary_invalidate_query_switchover_long.sh) (in query: CREATE TABLE dict_invalidate ENGINE = Memory AS SELECT 133 as dummy, toDateTime('2019-10-29 18:51:35') AS last_time FROM system.one), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:49.682214 [ 15299 ] {3f69a250-dee3-4709-939e-0733c656c853} TCPHandler: Code: 57. DB::Exception: Table test_e21kt9ba.dict_invalidate 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:09:49.862702 [ 3722 ] {} ExternalDictionariesLoader: Could not check if external dictionary '57f9bb0f-f990-41f9-adb7-59869240f571' was modified: Code: 60. DB::Exception: Unknown table expression identifier 'dict_invalidate' in scope SELECT max(last_time) FROM dict_invalidate. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa04d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334db18a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033426e8d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:195: DB::ClickHouseDictionarySource::doInvalidateQuery(String const&) const @ 0x0000000020b1a98f 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:0: DB::ClickHouseDictionarySource::isModified() const @ 0x0000000020b18739 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::isModified() const @ 0x0000000020d47010 19. ./build_docker/./src/Interpreters/ExternalLoader.cpp:669: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x00000000347de1f0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x00000000347dcf23 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347e4126 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347e3edf 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:50.777273 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:51.845004 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:52.302393 [ 4240 ] {f3d4f4d2-a869-440c-980a-c8025a1c4bd4} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:49050) (comment: 01040_dictionary_invalidate_query_switchover_long.sh) (in query: DROP DATABASE IF EXISTS test_e21kt9ba ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:09:52.304290 [ 4240 ] {f3d4f4d2-a869-440c-980a-c8025a1c4bd4} DynamicQueryHandler: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:52.960077 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:54.052494 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:54.869602 [ 3722 ] {} ExternalDictionariesLoader: Could not check if external dictionary '57f9bb0f-f990-41f9-adb7-59869240f571' was modified: Code: 60. DB::Exception: Unknown table expression identifier 'dict_invalidate' in scope SELECT max(last_time) FROM dict_invalidate. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa04d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334db18a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033426e8d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:195: DB::ClickHouseDictionarySource::doInvalidateQuery(String const&) const @ 0x0000000020b1a98f 17. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:0: DB::ClickHouseDictionarySource::isModified() const @ 0x0000000020b18739 18. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::isModified() const @ 0x0000000020d47010 19. ./build_docker/./src/Interpreters/ExternalLoader.cpp:669: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x00000000347de1f0 20. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x00000000347dcf23 21. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000347e4126 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000347e3edf 23. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:55.159204 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:56.251018 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:56.334407 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:57.391524 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:58.221166 [ 3642 ] {} test_1.t1 (c271963a-b599-4f9d-bb51-84a1e18190fd): Removing temporary directory /var/lib/clickhouse/store/c27/c271963a-b599-4f9d-bb51-84a1e18190fd/tmp_mut_1_1_1_0_3/ 2025.03.31 19:09:58.287524 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:58.505128 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:09:58.553995 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:58.554431 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:58.974098 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:58.977035 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:09:59.541210 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:00.189502 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:00.192030 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:00.563998 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:00.939362 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:00.941630 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:01.608824 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:01.838035 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:01.840899 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:02.066748 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:02.069640 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:02.435556 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:02.438470 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:02.644527 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:03.299327 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:03.301947 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:03.668119 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:04.359046 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:04.361459 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:04.691023 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:04.826986 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:04.827530 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:05.779013 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:06.060520 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:06.063664 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:06.697456 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:06.699952 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:06.865652 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:07.076220 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:07.078775 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:07.833169 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:07.835947 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:08.076930 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:08.512038 [ 3600 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ccd9e83a-9834-41dc-89e2-4a5d7824dd6d::202503_1_88_18}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:08.927170 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:08.930020 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:09.191500 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:09.551813 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:09.553899 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:10.276358 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:10.684385 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:10.687050 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:11.339558 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:11.476575 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:11.477035 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:11.963111 [ 3830 ] {00f6d9ea-fb6e-4b3f-b9d8-64897a437193} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value_' in scope SELECT value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56268) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT value_ FROM test_table 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:11.965499 [ 3830 ] {00f6d9ea-fb6e-4b3f-b9d8-64897a437193} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value_' in scope SELECT value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:12.438402 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:12.552601 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:12.555585 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:13.088636 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:13.089074 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:13.626769 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:14.017397 [ 3830 ] {161ba97c-877e-426a-bdd0-959a57d8cbc1} executeQuery: Code: 47. DB::Exception: Identifier 'test_table.value_' cannot be resolved from table with name test_0i4nvr1d.test_table. In scope SELECT test_table.value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56314) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_table.value_ FROM test_table 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:14.019932 [ 3830 ] {161ba97c-877e-426a-bdd0-959a57d8cbc1} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table.value_' cannot be resolved from table with name test_0i4nvr1d.test_table. In scope SELECT test_table.value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:14.280729 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:14.284027 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:14.471419 [ 4240 ] {748baf3b-a4cb-4685-90ae-79f5ab816ea7} 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.10457.altinitytest (altinity build)) (from [::1]:56298) (comment: 02761_ddl_initial_query_id.sh) (in query: SELECT normalizeQuery(replace(query, currentDatabase(), 'default')) FROM system.query_log WHERE initial_query_id = 'mnvozxzyhr foo' AND type != 'QueryStart' ORDER BY event_time_microseconds), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ce71b2 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&) @ 0x0000000039ce966a 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 @ 0x0000000032630982 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263138d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce0b44 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) @ 0x0000000039ce0469 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&) @ 0x000000003999ab28 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 @ 0x000000003998fbb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c03fa33 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf9e973 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:14.477200 [ 4240 ] {748baf3b-a4cb-4685-90ae-79f5ab816ea7} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ce71b2 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&) @ 0x0000000039ce966a 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 @ 0x0000000032630982 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263138d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce0b44 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) @ 0x0000000039ce0469 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&) @ 0x000000003999ab28 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 @ 0x000000003998fbb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c03fa33 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf9e973 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:14.761032 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:14.796424 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:14.796966 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:14.803158 [ 12294 ] {71bff834-c543-41a3-8457-87bdfb4c2286} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'test_tabl.value_' in scope SELECT test_tabl.value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56350) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_tabl.value_ FROM test_table 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:14.805419 [ 12294 ] {71bff834-c543-41a3-8457-87bdfb4c2286} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'test_tabl.value_' in scope SELECT test_tabl.value_ FROM test_table SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:15.350198 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:15.352992 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:15.686910 [ 4240 ] {2a56be89-c870-4820-9ce7-aa8f4cc40a8c} executeQuery: Code: 47. DB::Exception: Identifier 'test_table.value_' cannot be resolved from table with name test_table_alias. In scope SELECT test_table.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56360) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_table.value_ FROM test_table AS test_table_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:15.689198 [ 4240 ] {2a56be89-c870-4820-9ce7-aa8f4cc40a8c} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table.value_' cannot be resolved from table with name test_table_alias. In scope SELECT test_table.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:15.823764 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:16.022075 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:16.022523 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:16.561474 [ 12294 ] {c60a9649-2f62-4e86-9b44-e8d2cc2930b1} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'test_tabl.value_' in scope SELECT test_tabl.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56406) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_tabl.value_ FROM test_table AS test_table_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:16.563798 [ 12294 ] {c60a9649-2f62-4e86-9b44-e8d2cc2930b1} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'test_tabl.value_' in scope SELECT test_tabl.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:16.784008 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:16.875321 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:17.147936 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:17.280329 [ 4240 ] {7405d2df-ed3c-41cd-9e27-64b1675de8cb} executeQuery: Code: 47. DB::Exception: Identifier 'test_table_alias.value_' cannot be resolved from table with name test_table_alias. In scope SELECT test_table_alias.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_alias.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56432) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_table_alias.value_ FROM test_table AS test_table_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:17.283091 [ 4240 ] {7405d2df-ed3c-41cd-9e27-64b1675de8cb} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table_alias.value_' cannot be resolved from table with name test_table_alias. In scope SELECT test_table_alias.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_alias.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:17.931798 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:18.028585 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:18.031880 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:18.104235 [ 4240 ] {8617c179-aad7-4581-b036-cb8f9f49c28d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'test_table_alia.value_' in scope SELECT test_table_alia.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_alias.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56460) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_table_alia.value_ FROM test_table AS test_table_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:18.107908 [ 4240 ] {8617c179-aad7-4581-b036-cb8f9f49c28d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'test_table_alia.value_' in scope SELECT test_table_alia.value_ FROM test_table AS test_table_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_alias.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:18.823719 [ 4240 ] {5d5894b1-fdb5-4129-ad7a-d6fd1a722d90} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value_' in scope SELECT value_ FROM (SELECT 1 AS value) SETTINGS enable_analyzer = 1. Maybe you meant: ['value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56476) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT value_ FROM (SELECT 1 AS value) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:18.826038 [ 4240 ] {5d5894b1-fdb5-4129-ad7a-d6fd1a722d90} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value_' in scope SELECT value_ FROM (SELECT 1 AS value) SETTINGS enable_analyzer = 1. Maybe you meant: ['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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:18.835746 [ 12294 ] {e383c20f-e3d2-478d-aa30-07edc12959b3} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56464) (comment: 03164_analyzer_validate_tree_size.sql) (in query: CREATE TABLE t ( c1 Int64 , c2 Int64 , c3 Int64 , c4 Int64 , c5 Int64 , c6 Int64 , c7 Int64 , c8 Int64 , c9 Int64 , c10 Int64 , c11 Int64 , c12 Int64 , c13 Int64 , c14 Int64 , c15 Int64 , c16 Int64 , c17 Int64 , c18 Int64 , c19 Int64 , c20 Int64 , c21 Int64 , c22 Int64 , c23 Int64 , c24 Int64 , c25 Int64 , c26 Int64 , c27 Int64 , c28 Int64 , c29 Int64 , c30 Int64 , c31 Int64 , c32 Int64 , c33 Int64 , c34 Int64 , c35 Int64 , c36 Int64 , c37 Int64 , c38 Int64 , c39 Int64 , c40 Int64 , c41 Int64 , c42 Int64 , c43 Int64 , c44 Int64 , c45 Int64 , c46 Int64 , c47 Int64 , c48 Int64 , c49 Int64 , c50 Int64 , c51 Int64 , c52 Int64 , c53 Int64 , c54 Int64 , c55 Int64 , c56 Int64 , c57 Int64 , c58 Int64 , c59 Int64 , c60 Int64 , c61 Int64 , c62 Int64 , c63 Int64 , c64 Int64 , c65 Int64 , c66 Int64 , c67 Int64 , c68 Int64 , c69 Int64 , c70 Int64 , c71 Int64 , c72 Int64 , c73 Int64 , c74 Int64 , c75 Int64 , c76 Int64 , c77 Int64 , c78 Int64 , c79 Int64 , c80 Int64 , c81 Int64 , c82 Int64 , c83 Int64 , c84 Int64 , c85 Int64 , c86 Int64 , c87 Int64 , c88 Int64 , c89 Int64 , c90 Int64 , c91 Int64 , c92 Int64 , c93 Int64 , c94 Int64 , c95 Int64 , c96 Int64 , c97 Int64 , c98 Int64 , c99 Int64 , c100 Int64 , c101 Int64 , c102 Int64 , c103 Int64 , c104 Int64 , c105 Int64 , c106 Int64 , c107 Int64 , c108 Int64 , c109 Int64 , c110 Int64 , c111 Int64 , c112 Int64 , c113 Int64 , c114 Int64 , c115 Int64 , c116 Int64 , c117 Int64 , c118 Int64 , c119 Int64 , c120 Int64 , c121 Int64 , c122 Int64 , c123 Int64 , c124 Int64 , c125 Int64 , c126 Int64 , c127 Int64 , c128 Int64 , c129 Int64 , c130 Int64 , c131 Int64 , c132 Int64 , c133 Int64 , c134 Int64 , c135 Int64 , c136 Int64 , c137 Int64 , c138 Int64 , c139 Int64 , c140 Int64 , c141 Int64 , c142 Int64 , c143 Int64 , c144 Int64 , c145 Int64 , c146 Int64 , c147 Int64 , c148 Int64 , c149 Int64 , c150 Int64 , c151 Int64 , c152 Int64 , c153 Int64 , c154 Int64 , c155 Int64 , c156 Int64 , c157 Int64 , c158 Int64 , c159 Int64 , c160 Int64 , c161 Int64 , c162 Int64 , c163 Int64 , c164 Int64 , c165 Int64 , c166 Int64 , c167 Int64 , c168 Int64 , c169 Int64 , c170 Int64 , c171 Int64 , c172 Int64 , c173 Int64 , c174 Int64 , c175 Int64 , c176 Int64 , c177 Int64 , c178 Int64 , c179 Int64 , c180 Int64 , c181 Int64 , c182 Int64 , c183 Int64 , c184 Int64 , c185 Int64 , c186 Int64 , c187 Int64 , c188 Int64 , c189 Int64 , c190 Int64 , c191 Int64 , c192 Int64 , c193 Int64 , c194 Int64 , c195 Int64 , c196 Int64 , c197 Int64 , c198 Int64 , c199 Int64 , c200 Int64 , c201 Int64 , c202 Int64 , c203 Int64 , c204 Int64 , c205 Int64 , c206 Int64 , c207 Int64 , c208 Int64 , c209 Int64 , c210 Int64 , c211 Int64 , c212 Int64 , c213 Int64 , c214 Int64 , c215 Int64 , c216 Int64 , c217 Int64 , c218 Int64 , c219 Int64 , c220 Int64 , c221 Int64 , c222 Int64 , c223 Int64 , c224 Int64 , c225 Int64 , c226 Int64 , c227 Int64 , c228 Int64 , c229 Int64 , c230 Int64 , c231 Int64 , c232 Int64 , c233 Int64 , c234 Int64 , c235 Int64 , c236 Int64 , c237 Int64 , c238 Int64 , c239 Int64 , c240 Int64 , c241 Int64 , c242 Int64 , c243 Int64 , c244 Int64 , c245 Int64 , c246 Int64 , c247 Int64 , c248 Int64 , c249 Int64 , c250 Int64 , c251 Int64 , c252 Int64 , c253 Int64 , c254 Int64 , c255 Int64 , c256 Int64 , c257 Int64 , c258 Int64 , c259 Int64 , c260 Int64 , c261 Int64 , c262 Int64 , c263 Int64 , c264 Int64 , c265 Int64 , c266 Int64 , c267 Int64 , c268 Int64 , c269 Int64 , c270 Int64 , c271 Int64 , c272 Int64 , c273 Int64 , c274 Int64 , c275 Int64 , c276 Int64 , c277 Int64 , c278 Int64 , c279 Int64 , c280 Int64 , c281 Int64 , c282 Int64 , c283 Int64 , c284 Int64 , c285 Int64 , c286 Int64 , c287 Int64 , c288 Int64 , c289 Int64 , c290 Int64 , c291 Int64 , c292 Int64 , c293 Int64 , c294 Int64 , c295 Int64 , c296 Int64 , c297 Int64 , c298 Int64 , c299 Int64 , c300 Int64 , c301 Int64 , c302 Int64 , c303 Int64 , c304 Int64 , c305 Int64 , c306 Int64 , c307 Int64 , c308 Int64 , c309 Int64 , c310 Int64 , c311 Int64 , c312 Int64 , c313 Int64 , c314 Int64 , c315 Int64 , c316 Int64 , c317 Int64 , c318 Int64 , c319 Int64 , c320 Int64 , c321 Int64 , c322 Int64 , c323 Int64 , c324 Int64 , c325 Int64 , c326 Int64 , c327 Int64 , c328 Int64 , c329 Int64 , c330 Int64 , c331 Int64 , c332 Int64 , c333 Int64 , c334 Int64 , c335 Int64 , c336 Int64 , c337 Int64 , c338 Int64 , c339 Int64 , c340 Int64 , c341 Int64 , c342 Int64 , c343 Int64 , c344 Int64 , c345 Int64 , c346 Int64 , c347 Int64 , c348 Int64 , c349 Int64 , c350 Int64 , c351 Int64 , c352 Int64 , c353 Int64 , c354 Int64 , c355 Int64 , c356 Int64 , c357 Int64 , c358 Int64 , c359 Int64 , c360 Int64 , c361 Int64 , c362 Int64 , c363 Int64 , c364 Int64 , c365 Int64 , c366 Int64 , c367 Int64 , c368 Int64 , c369 Int64 , c370 Int64 , c371 Int64 , c372 Int64 , c373 Int64 , c374 Int64 , c375 Int64 , c376 Int64 , c377 Int64 , c378 Int64 , c379 Int64 , c380 Int64 , c381 Int64 , c382 Int64 , c383 Int64 , c384 Int64 , c385 Int64 , c386 Int64 , c387 Int64 , c388 Int64 , c389 Int64 , c390 Int64 , c391 Int64 , c392 Int64 , c393 Int64 , c394 Int64 , c395 Int64 , c396 Int64 , c397 Int64 , c398 Int64 , c399 Int64 , c400 Int64 , c401 Int64 , c402 Int64 , c403 Int64 , c404 Int64 , c405 Int64 , c406 Int64 , c407 Int64 , c408 Int64 , c409 Int64 , c410 Int64 , c411 Int64 , c412 Int64 , c413 Int64 , c414 Int64 , c415 Int64 , c416 Int64 , c417 Int64 , c418 Int64 , c419 Int64 , c420 Int64 , c421 Int64 , c422 Int64 , c423 Int64 , c424 Int64 , c425 Int64 , c426 Int64 , c427 Int64 , c428 Int64 , c429 Int64 , c430 Int64 , c431 Int64 , c432 Int64 , c433 Int64 , c434 Int64 , c435 Int64 , c436 Int64 , c437 Int64 , c438 Int64 , c439 Int64 , c440 Int64 , c441 Int64 , c442 Int64 , c443 Int64 , c444 Int64 , c445 Int64 , c446 Int64 , c447 Int64 , c448 Int64 , c449 Int64 , c450 Int64 , c451 Int64 , c452 Int64 , c453 Int64 , c454 Int64 , c455 Int64 , c456 Int64 , c457 Int64 , c458 Int64 , c459 Int64 , c460 Int64 , c461 Int64 , c462 Int64 , c463 Int64 , c464 Int64 , c465 Int64 , c466 Int64 , c467 Int64 , c468 Int64 , c469 Int64 , c470 Int64 , c471 Int64 , c472 Int64 , c473 Int64 , c474 Int64 , c475 Int64 , c476 Int64 , c477 Int64 , c478 Int64 , c479 Int64 , c480 Int64 , c481 Int64 , c482 Int64 , c483 Int64 , c484 Int64 , c485 Int64 , c486 Int64 , c487 Int64 , c488 Int64 , c489 Int64 , c490 Int64 , c491 Int64 , c492 Int64 , c493 Int64 , c494 Int64 , c495 Int64 , c496 Int64 , c497 Int64 , c498 Int64 , c499 Int64 , c500 Int64 , b1 Int64 , b2 Int64 , b3 Int64 , b4 Int64 , b5 Int64 , b6 Int64 , b7 Int64 , b8 Int64 , b9 Int64 , b10 Int64 , b11 Int64 , b12 Int64 , b13 Int64 , b14 Int64 , b15 Int64 , b16 Int64 , b17 Int64 , b18 Int64 , b19 Int64 , b20 Int64 , b21 Int64 , b22 Int64 , b23 Int64 , b24 Int64 , b25 Int64 , b26 Int64 , b27 Int64 , b28 Int64 , b29 Int64 , b30 Int64 , b31 Int64 , b32 Int64 , b33 Int64 , b34 Int64 , b35 Int64 , b36 Int64 , b37 Int64 , b38 Int64 , b39 Int64 , b40 Int64 , b41 Int64 , b42 Int64 , b43 Int64 , b44 Int64 , b45 Int64 , b46 Int64 , b47 Int64 , b48 Int64 , b49 Int64 , b50 Int64 , b51 Int64 , b52 Int64 , b53 Int64 , b54 Int64 , b55 Int64 , b56 Int64 , b57 Int64 , b58 Int64 , b59 Int64 , b60 Int64 , b61 Int64 , b62 Int64 , b63 Int64 , b64 Int64 , b65 Int64 , b66 Int64 , b67 Int64 , b68 Int64 , b69 Int64 , b70 Int64 , b71 Int64 , b72 Int64 , b73 Int64 , b74 Int64 , b75 Int64 , b76 Int64 , b77 Int64 , b78 Int64 , b79 Int64 , b80 Int64 , b81 Int64 , b82 Int64 , b83 Int64 , b84 Int64 , b85 Int64 , b86 Int64 , b87 Int64 , b88 Int64 , b89 Int64 , b90 Int64 , b91 Int64 , b92 Int64 , b93 Int64 , b94 Int64 , b95 Int64 , b96 Int64 , b97 Int64 , b98 Int64 , b99 Int64 , b100 Int64 , b101 Int64 , b102 Int64 , b103 Int64 , b104 Int64 , b105 Int64 , b106 Int64 , b107 Int64 , b108 Int64 , b109 Int64 , b110 Int64 , b111 Int64 , b112 Int64 , b113 Int64 , b114 Int64 , b115 Int64 , b116 Int64 , b117 Int64 , b118 Int64 , b119 Int64 , b120 Int64 , b121 Int64 , b122 Int64 , b123 Int64 , b124 Int64 , b125 Int64 , b126 Int64 , b127 Int64 , b128 Int64 , b129 Int64 , b130 Int64 , b131 Int64 , b132 Int64 , b133 Int64 , b134 Int64 , b135 Int64 , b136 Int64 , b137 Int64 , b138 Int64 , b139 Int64 , b140 Int64 , b141 Int64 , b142 Int64 , b143 Int64 , b144 Int64 , b145 Int64 , b146 Int64 , b147 Int64 , b148 Int64 , b149 Int64 , b150 Int64 , b151 Int64 , b152 Int64 , b153 Int64 , b154 Int64 , b155 Int64 , b156 Int64 , b157 Int64 , b158 Int64 , b159 Int64 , b160 Int64 , b161 Int64 , b162 Int64 , b163 Int64 , b164 Int64 , b165 Int64 , b166 Int64 , b167 Int64 , b168 Int64 , b169 Int64 , b170 Int64 , b171 Int64 , b172 Int64 , b173 Int64 , b174 Int64 , b175 Int64 , b176 Int64 , b177 Int64 , b178 Int64 , b179 Int64 , b180 Int64 , b181 Int64 , b182 Int64 , b183 Int64 , b184 Int64 , b185 Int64 , b186 Int64 , b187 Int64 , b188 Int64 , b189 Int64 , b190 Int64 , b191 Int64 , b192 Int64 , b193 Int64 , b194 Int64 , b195 Int64 , b196 Int64 , b197 Int64 , b198 Int64 , b199 Int64 , b200 Int64 , b201 Int64 , b202 Int64 , b203 Int64 , b204 Int64 , b205 Int64 , b206 Int64 , b207 Int64 , b208 Int64 , b209 Int64 , b210 Int64 , b211 Int64 , b212 Int64 , b213 Int64 , b214 Int64 , b215 Int64 , b216 Int64 , b217 Int64 , b218 Int64 , b219 Int64 , b220 Int64 , b221 Int64 , b222 Int64 , b223 Int64 , b224 Int64 , b225 Int64 , b226 Int64 , b227 Int64 , b228 Int64 , b229 Int64 , b230 Int64 , b231 Int64 , b232 Int64 , b233 Int64 , b234 Int64 , b235 Int64 , b236 Int64 , b237 Int64 , b238 Int64 , b239 Int64 , b240 Int64 , b241 Int64 , b242 Int64 , b243 Int64 , b244 Int64 , b245 Int64 , b246 Int64 , b247 Int64 , b248 Int64 , b249 Int64 , b250 Int64 , b251 Int64 , b252 Int64 , b253 Int64 , b254 Int64 , b255 Int64 , b256 Int64 , b257 Int64 , b258 Int64 , b259 Int64 , b260 Int64 , b261 Int64 , b262 Int64 , b263 Int64 , b264 Int64 , b265 Int64 , b266 Int64 , b267 Int64 , b268 Int64 , b269 Int64 , b270 Int64 , b271 Int64 , b272 Int64 , b273 Int64 , b274 Int64 , b275 Int64 , b276 Int64 , b277 Int64 , b278 Int64 , b279 Int64 , b280 Int64 , b281 Int64 , b282 Int64 , b283 Int64 , b284 Int64 , b285 Int64 , b286 Int64 , b287 Int64 , b288 Int64 , b289 Int64 , b290 Int64 , b291 Int64 , b292 Int64 , b293 Int64 , b294 Int64 , b295 Int64 , b296 Int64 , b297 Int64 , b298 Int64 , b299 Int64 , b300 Int64 , b301 Int64 , b302 Int64 , b303 Int64 , b304 Int64 , b305 Int64 , b306 Int64 , b307 Int64 , b308 Int64 , b309 Int64 , b310 Int64 , b311 Int64 , b312 Int64 , b313 Int64 , b314 Int64 , b315 Int64 , b316 Int64 , b317 Int64 , b318 Int64 , b319 Int64 , b320 Int64 , b321 Int64 , b322 Int64 , b323 Int64 , b324 Int64 , b325 Int64 , b326 Int64 , b327 Int64 , b328 Int64 , b329 Int64 , b330 Int64 , b331 Int64 , b332 Int64 , b333 Int64 , b334 Int64 , b335 Int64 , b336 Int64 , b337 Int64 , b338 Int64 , b339 Int64 , b340 Int64 , b341 Int64 , b342 Int64 , b343 Int64 , b344 Int64 , b345 Int64 , b346 Int64 , b347 Int64 , b348 Int64 , b349 Int64 , b350 Int64 , b351 Int64 , b352 Int64 , b353 Int64 , b354 Int64 , b355 Int64 , b356 Int64 , b357 Int64 , b358 Int64 , b359 Int64 , b360 Int64 , b361 Int64 , b362 Int64 , b363 Int64 , b364 Int64 , b365 Int64 , b366 Int64 , b367 Int64 , b368 Int64 , b369 Int64 , b370 Int64 , b371 Int64 , b372 Int64 , b373 Int64 , b374 Int64 , b375 Int64 , b376 Int64 , b377 Int64 , b378 Int64 , b379 Int64 , b380 Int64 , b381 Int64 , b382 Int64 , b383 Int64 , b384 Int64 , b385 Int64 , b386 Int64 , b387 Int64 , b388 Int64 , b389 Int64 , b390 Int64 , b391 Int64 , b392 Int64 , b393 Int64 , b394 Int64 , b395 Int64 , b396 Int64 , b397 Int64 , b398 Int64 , b399 Int64 , b400 Int64 , b401 Int64 , b402 Int64 , b403 Int64 , b404 Int64 , b405 Int64 , b406 Int64 , b407 Int64 , b408 Int64 , b409 Int64 , b410 Int64 , b411 Int64 , b412 Int64 , b413 Int64 , b414 Int64 , b415 Int64 , b416 Int64 , b417 Int64 , b418 Int64 , b419 Int64 , b420 Int64 , b421 Int64 , b422 Int64 , b423 Int64 , b424 Int64 , b425 Int64 , b426 Int64 , b427 Int64 , b428 Int64 , b429 Int64 , b430 Int64 , b431 Int64 , b432 Int64 , b433 Int64 , b434 Int64 , b435 Int64 , b436 Int64 , b437 Int64 , b438 Int64 , b439 Int64 , b440 Int64 , b441 Int64 , b442 Int64 , b443 Int64 , b444 Int64 , b445 Int64 , b446 Int64 , b447 Int64 , b448 Int64 , b449 Int64 , b450 Int64 , b451 Int64 , b452 Int64 , b453 Int64 , b454 Int64 , b455 Int64 , b456 Int64 , b457 Int64 , b458 Int64 , b459 Int64 , b460 Int64 , b461 Int64 , b462 Int64 , b463 Int64 , b464 Int64 , b465 Int64 , b466 Int64 , b467 Int64 , b468 Int64 , b469 Int64 , b470 Int64 , b471 Int64 , b472 Int64 , b473 Int64 , b474 Int64 , b475 Int64 , b476 Int64 , b477 Int64 , b478 Int64 , b479 Int64 , b480 Int64 , b481 Int64 , b482 Int64 , b483 Int64 , b484 Int64 , b485 Int64 , b486 Int64 , b487 Int64 , b488 Int64 , b489 Int64 , b490 Int64 , b491 Int64 , b492 Int64 , b493 Int64 , b494 Int64 , b495 Int64 , b496 Int64 , b497 Int64 , b498 Int64 , b499 Int64 , b500 Int64 ) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:18.843494 [ 12294 ] {e383c20f-e3d2-478d-aa30-07edc12959b3} TCPHandler: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:18.997608 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:19.249244 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:19.251799 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:19.698742 [ 4240 ] {43d92aa5-6006-4c39-ba9e-92909907346e} executeQuery: Code: 47. DB::Exception: Identifier 'subquery.value_' cannot be resolved from subquery with name subquery. In scope SELECT subquery.value_ FROM (SELECT 1 AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35384) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT subquery.value_ FROM (SELECT 1 AS value) AS subquery 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:19.700620 [ 4240 ] {43d92aa5-6006-4c39-ba9e-92909907346e} TCPHandler: Code: 47. DB::Exception: Identifier 'subquery.value_' cannot be resolved from subquery with name subquery. In scope SELECT subquery.value_ FROM (SELECT 1 AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:20.089019 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:20.354902 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:20.356287 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039d03d22 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f91bf1 19. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000034f9c58b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e68dd2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aa57c 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:20.437571 [ 4240 ] {4013f730-d020-413e-9ccc-b4863ff3ec83} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'subquer.value_' in scope SELECT subquer.value_ FROM (SELECT 1 AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35390) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT subquer.value_ FROM (SELECT 1 AS value) AS subquery 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:20.439751 [ 4240 ] {4013f730-d020-413e-9ccc-b4863ff3ec83} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'subquer.value_' in scope SELECT subquer.value_ FROM (SELECT 1 AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:20.596321 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:20.596784 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:21.130445 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:21.167941 [ 12294 ] {a62da2fc-8334-4fb8-9c79-ebc014c46926} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value_' in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35404) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH cte_subquery AS (SELECT 1 AS value) SELECT value_ FROM cte_subquery 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:21.170438 [ 12294 ] {a62da2fc-8334-4fb8-9c79-ebc014c46926} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value_' in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:21.273673 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:21.276434 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:21.783199 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:21.786743 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:22.001158 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:22.001685 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:22.038001 [ 12294 ] {f4854a0d-7691-48aa-ab14-276e14f4bb7d} executeQuery: Code: 47. DB::Exception: Identifier 'cte_subquery.value_' cannot be resolved from subquery. In scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35428) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery.value_ FROM cte_subquery 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:22.040031 [ 12294 ] {f4854a0d-7691-48aa-ab14-276e14f4bb7d} TCPHandler: Code: 47. DB::Exception: Identifier 'cte_subquery.value_' cannot be resolved from subquery. In scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:22.342970 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:22.847525 [ 4240 ] {dcf05a7c-dc01-4d93-b8cc-1cb53f6253a7} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'cte_subquer.value_' in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquer.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35444) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquer.value_ FROM cte_subquery 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:22.849619 [ 4240 ] {dcf05a7c-dc01-4d93-b8cc-1cb53f6253a7} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'cte_subquer.value_' in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquer.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:22.948798 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:22.951477 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:23.492430 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:23.618865 [ 4240 ] {b25f29db-8124-47bc-9271-2215f074c449} executeQuery: Code: 47. DB::Exception: Identifier 'cte_subquery_alias.value_' cannot be resolved from subquery with name cte_subquery_alias. In scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alias.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35482) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alias.value_ FROM cte_subquery AS cte_subquery_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:23.620765 [ 4240 ] {b25f29db-8124-47bc-9271-2215f074c449} TCPHandler: Code: 47. DB::Exception: Identifier 'cte_subquery_alias.value_' cannot be resolved from subquery with name cte_subquery_alias. In scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alias.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 9. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:10:23.990074 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:23.992578 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:24.305092 [ 4240 ] {71fc57ae-f9ee-4f74-a25f-762760da0fc2} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'cte_subquery_alia.value_' in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alia.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35498) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alia.value_ FROM cte_subquery AS cte_subquery_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:24.307085 [ 4240 ] {71fc57ae-f9ee-4f74-a25f-762760da0fc2} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'cte_subquery_alia.value_' in scope WITH cte_subquery AS (SELECT 1 AS value) SELECT cte_subquery_alia.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:24.508753 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:24.979005 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:24.979487 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:25.007806 [ 4240 ] {82de7320-7ecf-47d7-967c-02462c0a6280} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'constant_valu' in scope SELECT 1 AS constant_value, constant_valu SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35518) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT 1 AS constant_value, constant_valu 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:25.009642 [ 4240 ] {82de7320-7ecf-47d7-967c-02462c0a6280} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'constant_valu' in scope SELECT 1 AS constant_value, constant_valu SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:25.589162 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:25.796944 [ 4240 ] {21895a02-f614-4636-8c35-5f20b89f3f5c} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'constant_valu' in scope SELECT 1 AS constant_value, constant_valu SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35540) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT 1 AS constant_value, constant_valu 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:25.798896 [ 4240 ] {21895a02-f614-4636-8c35-5f20b89f3f5c} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'constant_valu' in scope SELECT 1 AS constant_value, constant_valu SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:26.061585 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:26.064667 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:26.580356 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:26.583242 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:26.658614 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:27.016873 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:27.017317 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:27.630359 [ 4240 ] {e20613ac-92af-4208-8749-027df8354a45} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35578) (comment: 00056_view.sql) (in query: DROP TABLE IF EXISTS 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:10:27.632450 [ 4240 ] {e20613ac-92af-4208-8749-027df8354a45} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:10:27.734072 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:27.736928 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:27.767566 [ 12294 ] {84d9bcfe-85ea-4948-9438-8b0e53f38574} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'constant_valu' in scope lambda_argument -> (lambda_argument + constant_valu). Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35564) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT 1 AS constant_value, arrayMap(lambda_argument -> lambda_argument + constant_valu, [1, 2, 3]) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000334c5e71 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033499545 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:27.769627 [ 12294 ] {84d9bcfe-85ea-4948-9438-8b0e53f38574} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'constant_valu' in scope lambda_argument -> (lambda_argument + constant_valu). Maybe you meant: ['constant_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000334c5e71 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033499545 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:27.774351 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:27.914264 [ 4240 ] {74587249-8dad-4086-baab-c9961c6bddc1} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0) -> throwIf(equals(__table1.number, 1000_UInt16)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35598) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:27.916265 [ 4240 ] {74587249-8dad-4086-baab-c9961c6bddc1} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0) -> throwIf(equals(__table1.number, 1000_UInt16)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:28.860337 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:28.874309 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:28.877360 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:29.708132 [ 12293 ] {1aa4cc06-ad7b-4e78-a57f-3e35c60b3dc2} executeQuery: Code: 395. DB::Exception: Number equals 1000: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35618) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000') FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001c575cfa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56fa7f 4. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 16. ./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*) @ 0x000000003ae9f89d 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:10:29.711000 [ 12293 ] {1aa4cc06-ad7b-4e78-a57f-3e35c60b3dc2} TCPHandler: Code: 395. DB::Exception: Number equals 1000: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::createRuntime(int, String const&) @ 0x000000001c575cfa 3. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56fa7f 4. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 5. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 6. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 7. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 9. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 11. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 12. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 16. ./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*) @ 0x000000003ae9f89d 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:10:29.883031 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:29.883505 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:29.965526 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:30.226588 [ 12294 ] {8e787dfe-d364-4811-b97d-e2dc4ac7f323} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'constant_valu' in scope (SELECT constant_valu). Maybe you meant: ['constant_value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35614) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH 1 AS constant_value SELECT (SELECT constant_valu) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343ef6d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 29. ? @ 0x00007f038ce47ac3 30. ? @ 0x00007f038ced9850 2025.03.31 19:10:30.228767 [ 12294 ] {8e787dfe-d364-4811-b97d-e2dc4ac7f323} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'constant_valu' in scope (SELECT constant_valu). Maybe you meant: ['constant_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343ef6d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 29. ? @ 0x00007f038ce47ac3 30. ? @ 0x00007f038ced9850 2025.03.31 19:10:30.621473 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:30.624477 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:31.004448 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:31.767256 [ 12294 ] {01affe50-93df-4d0d-8398-296272d15488} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value.value_' in scope SELECT value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45104) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT value.value_ FROM test_table_compound 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:31.769195 [ 12294 ] {01affe50-93df-4d0d-8398-296272d15488} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value.value_' in scope SELECT value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:31.898683 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:31.901559 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:32.083255 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:32.221803 [ 4240 ] {dd311e35-21af-4e70-9337-e7f2c1eeb7c2} executeQuery: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45092) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, char const*&&) @ 0x000000001c575e97 4. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c572350 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:32.224236 [ 4240 ] {dd311e35-21af-4e70-9337-e7f2c1eeb7c2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function throwIf doesn't match: passed 3, should be 1 or 2: In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, char const*&&) @ 0x000000001c575e97 4. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c572350 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:33.121633 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:33.122228 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:33.159016 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:33.488374 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:33.491541 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:33.986552 [ 12293 ] {2401c5ce-65ef-40b6-850b-7c1514dd6b4c} executeQuery: Code: 47. DB::Exception: Identifier test_table_compound.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_0i4nvr1d.test_table_compound. In scope SELECT test_table_compound.value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45158) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_table_compound.value.value_ FROM test_table_compound 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:33.988955 [ 12293 ] {2401c5ce-65ef-40b6-850b-7c1514dd6b4c} TCPHandler: Code: 47. DB::Exception: Identifier test_table_compound.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_0i4nvr1d.test_table_compound. In scope SELECT test_table_compound.value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:34.372287 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:34.374823 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:34.430824 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:34.757198 [ 12293 ] {958972de-a9eb-49cd-8b62-35172df3c862} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'test_tabl_compound.value.value_' in scope SELECT test_tabl_compound.value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45220) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_tabl_compound.value.value_ FROM test_table_compound 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:34.759407 [ 12293 ] {958972de-a9eb-49cd-8b62-35172df3c862} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'test_tabl_compound.value.value_' in scope SELECT test_tabl_compound.value.value_ FROM test_table_compound SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:34.918510 [ 4240 ] {7b8fcd74-fa2f-478a-b469-b5a5a613898f} executeQuery: Code: 43. DB::Exception: Third argument of function throwIf must be Int8, Int16 or Int32 (passed: UInt8): In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif = true. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45172) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c572cab 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:34.920703 [ 4240 ] {7b8fcd74-fa2f-478a-b469-b5a5a613898f} TCPHandler: Code: 43. DB::Exception: Third argument of function throwIf must be Int8, Int16 or Int32 (passed: UInt8): In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif = true. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000001c572cab 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083776e6 6. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 11. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:35.408297 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:35.408739 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:35.475522 [ 4240 ] {9ff898ce-bb06-40e8-80d9-ad932adb4481} executeQuery: Code: 47. DB::Exception: Identifier test_table_compound.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_table_compound_alias. In scope SELECT test_table_compound.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45250) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_table_compound.value.value_ FROM test_table_compound AS test_table_compound_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:35.477448 [ 4240 ] {9ff898ce-bb06-40e8-80d9-ad932adb4481} TCPHandler: Code: 47. DB::Exception: Identifier test_table_compound.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_table_compound_alias. In scope SELECT test_table_compound.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:35.505598 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:35.720179 [ 12294 ] {d5afade0-1a6f-4390-8dbe-103ed8b646d4} executeQuery: Code: 42. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(42_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(42_Int32, 'Int32'_String)) UInt8 : 1'. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45258) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(42)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:35.722776 [ 12294 ] {d5afade0-1a6f-4390-8dbe-103ed8b646d4} TCPHandler: Code: 42. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(42_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(42_Int32, 'Int32'_String)) UInt8 : 1'. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:35.931249 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:35.931703 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:36.379803 [ 12294 ] {1bc30a89-76a1-4868-94cc-5257b701054d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'test_tabl_compound.value.value_' in scope SELECT test_tabl_compound.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45276) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_tabl_compound.value.value_ FROM test_table_compound AS test_table_compound_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:36.382035 [ 12294 ] {1bc30a89-76a1-4868-94cc-5257b701054d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'test_tabl_compound.value.value_' in scope SELECT test_tabl_compound.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:36.598932 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:36.648519 [ 4187 ] {09f883f9-1170-4ddb-b5c2-e5f2f09bc0ce} executeQuery: Code: 0. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(0_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(0_Int32, 'Int32'_String)) UInt8 : 1'. (OK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45302) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(0)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:36.650917 [ 4187 ] {09f883f9-1170-4ddb-b5c2-e5f2f09bc0ce} TCPHandler: Code: 0. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(0_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(0_Int32, 'Int32'_String)) UInt8 : 1'. (OK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:36.865484 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:36.867805 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:37.105034 [ 12293 ] {0a52674e-68e9-4d6c-a380-9e7d2a0893ad} executeQuery: Code: 47. DB::Exception: Identifier test_table_compound_alias.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_table_compound_alias. In scope SELECT test_table_compound_alias.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound_alias.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45318) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_table_compound_alias.value.value_ FROM test_table_compound AS test_table_compound_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:37.107157 [ 12293 ] {0a52674e-68e9-4d6c-a380-9e7d2a0893ad} TCPHandler: Code: 47. DB::Exception: Identifier test_table_compound_alias.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from table with name test_table_compound_alias. In scope SELECT test_table_compound_alias.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound_alias.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:37.408986 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:37.412232 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:37.524830 [ 12294 ] {7e6892ec-98b2-458c-9fb8-0ae4ade00737} executeQuery: Code: 101. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(101_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(101_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_CLIENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45322) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(101)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:37.527581 [ 12294 ] {7e6892ec-98b2-458c-9fb8-0ae4ade00737} TCPHandler: Code: 101. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(101_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(101_Int32, 'Int32'_String)) UInt8 : 1'. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:37.707044 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:37.841662 [ 12293 ] {77d44fc8-ad63-4d3e-8659-ae832b2d240e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'test_table_compound_alia.value.value_' in scope SELECT test_table_compound_alia.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound_alias.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45348) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_table_compound_alia.value.value_ FROM test_table_compound AS test_table_compound_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:37.843635 [ 12293 ] {77d44fc8-ad63-4d3e-8659-ae832b2d240e} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'test_table_compound_alia.value.value_' in scope SELECT test_table_compound_alia.value.value_ FROM test_table_compound AS test_table_compound_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_compound_alias.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:38.306102 [ 12294 ] {0726d4ce-8cf4-4c08-860e-e97c662e8ef5} executeQuery: Code: 102. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(102_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(102_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_SERVER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45350) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(102)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:38.308706 [ 12294 ] {0726d4ce-8cf4-4c08-860e-e97c662e8ef5} TCPHandler: Code: 102. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(102_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(102_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:38.346096 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:38.348558 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:38.425455 [ 12293 ] {ce47d97b-3dd1-4708-8b8f-069ca69cef61} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45352) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:38.427590 [ 12293 ] {ce47d97b-3dd1-4708-8b8f-069ca69cef61} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:38.554175 [ 4187 ] {eeaa7eba-3c32-4164-8a7a-1fad145076bf} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value.value_' in scope SELECT value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45364) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT value.value_ FROM (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:38.556133 [ 4187 ] {eeaa7eba-3c32-4164-8a7a-1fad145076bf} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value.value_' in scope SELECT value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:38.744457 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:39.131553 [ 12293 ] {2e3167a5-fd29-42e3-bec2-8742ba4573ed} executeQuery: Code: 1001. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1001_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1001_Int32, 'Int32'_String)) UInt8 : 1'. (STD_EXCEPTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45390) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(1001)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:39.134077 [ 12293 ] {2e3167a5-fd29-42e3-bec2-8742ba4573ed} TCPHandler: Code: 1001. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1001_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1001_Int32, 'Int32'_String)) UInt8 : 1'. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:39.368040 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:39.368551 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:39.407776 [ 2854 ] {344922bc-dffc-46ff-baea-9e7fb34f924c} executeQuery: Code: 47. DB::Exception: Identifier subquery.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery with name subquery. In scope SELECT subquery.value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40368) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT subquery.value.value_ FROM (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:39.409662 [ 2854 ] {344922bc-dffc-46ff-baea-9e7fb34f924c} TCPHandler: Code: 47. DB::Exception: Identifier subquery.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery with name subquery. In scope SELECT subquery.value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:39.793285 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:39.948671 [ 12293 ] {b457b4a9-661b-40c3-9a91-927cc9137d80} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40392) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(1002)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:39.951289 [ 12293 ] {b457b4a9-661b-40c3-9a91-927cc9137d80} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:40.155570 [ 4187 ] {caefddcf-c680-45fe-8be7-b808cb6cbe19} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'subquer.value.value_' in scope SELECT subquer.value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40402) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT subquer.value.value_ FROM (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:40.158047 [ 4187 ] {caefddcf-c680-45fe-8be7-b808cb6cbe19} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'subquer.value.value_' in scope SELECT subquer.value.value_ FROM (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) AS subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['subquery.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:40.221972 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:40.222388 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:40.812639 [ 4187 ] {f291e9d5-c33a-407c-8019-1df1d5f29625} executeQuery: Code: 999999. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(999999_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(999999_Int32, 'Int32'_String)) UInt8 : 1'. () (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40410) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(999999)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:40.814916 [ 4187 ] {f291e9d5-c33a-407c-8019-1df1d5f29625} TCPHandler: Code: 999999. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(999999_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(999999_Int32, 'Int32'_String)) UInt8 : 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:40.845387 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:40.976568 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:40.977102 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:41.008251 [ 15299 ] {c4df3675-8de6-488d-b2a7-3c8c75c394fc} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'value.value_' in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40432) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH cte_subquery AS (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) SELECT value.value_ FROM cte_subquery 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:41.010702 [ 15299 ] {c4df3675-8de6-488d-b2a7-3c8c75c394fc} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'value.value_' in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:41.488872 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:41.491669 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:41.690916 [ 12293 ] {693b7830-1253-4583-96fd-ee9d99ae2c3b} executeQuery: Code: -1. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(-1_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(-1_Int32, 'Int32'_String)) UInt8 : 1'. () (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40450) (comment: 00602_throw_if.sh) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(-1)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:41.693454 [ 12293 ] {693b7830-1253-4583-96fd-ee9d99ae2c3b} TCPHandler: Code: -1. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(-1_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(-1_Int32, 'Int32'_String)) UInt8 : 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c56f79b 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 17. ./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*) @ 0x000000003ae9f89d 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:10:41.792836 [ 4187 ] {60349571-abb8-4300-8bc5-063451e71f00} executeQuery: Code: 47. DB::Exception: Identifier cte_subquery.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery. In scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery.value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40456) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH cte_subquery AS (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery.value.value_ FROM cte_subquery 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:41.795155 [ 4187 ] {60349571-abb8-4300-8bc5-063451e71f00} TCPHandler: Code: 47. DB::Exception: Identifier cte_subquery.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery. In scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery.value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:41.865062 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:41.873082 [ 15299 ] {4e9909c3-4b19-4d88-b0f2-9d241fa89c10} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40472) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:41.875152 [ 15299 ] {4e9909c3-4b19-4d88-b0f2-9d241fa89c10} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:42.420738 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:42.424152 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:42.486926 [ 2854 ] {99d935c3-3123-45e6-937f-053ec5e2908f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'cte_subquer.value.value_' in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquer.value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40494) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH cte_subquery AS (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquer.value.value_ FROM cte_subquery 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:42.488872 [ 2854 ] {99d935c3-3123-45e6-937f-053ec5e2908f} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'cte_subquer.value.value_' in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquer.value.value_ FROM cte_subquery SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:42.954222 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:43.043874 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:43.044286 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:43.208536 [ 15299 ] {a0ae9cb0-e22a-4986-9e33-4e9977489c6a} executeQuery: Code: 47. DB::Exception: Identifier cte_subquery_alias.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery with name cte_subquery_alias. In scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alias.value.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40540) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH cte_subquery AS (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alias.value.value_ FROM cte_subquery AS cte_subquery_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:43.210697 [ 15299 ] {a0ae9cb0-e22a-4986-9e33-4e9977489c6a} TCPHandler: Code: 47. DB::Exception: Identifier cte_subquery_alias.value.value_ nested path value_ cannot be resolved from type Tuple(value_1 String) from subquery with name cte_subquery_alias. In scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alias.value.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>, DB::Identifier const&, DB::IdentifierView&, String&&, String&, String&&, String&&) @ 0x00000000335c33c7 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:484: DB::IdentifierResolver::tryResolveIdentifierFromCompoundExpression(DB::Identifier const&, unsigned long, std::shared_ptr const&, String, DB::IdentifierResolveScope&, bool) @ 0x00000000335a22bd 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:765: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335ab158 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 10. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:44.017554 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:44.055530 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:44.057821 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:44.075733 [ 4240 ] {227e869a-26ed-4b04-bb8b-a6647030d302} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'cte_subquery_alia.value.value_' in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alia.value.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40574) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH cte_subquery AS (SELECT cast(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alia.value.value_ FROM cte_subquery AS cte_subquery_alias 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:44.142476 [ 4240 ] {227e869a-26ed-4b04-bb8b-a6647030d302} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'cte_subquery_alia.value.value_' in scope WITH cte_subquery AS (SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS value) SELECT cte_subquery_alia.value.value_ FROM cte_subquery AS cte_subquery_alias SETTINGS enable_analyzer = 1. Maybe you meant: ['cte_subquery_alias.value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:44.624336 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:44.627164 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:44.814862 [ 15299 ] {a8d3a870-c7cb-4e15-bbae-7c6ba22f9d8d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'constant_value.value_' in scope SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_value.value_ SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40614) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT cast(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_value.value_ 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:44.817202 [ 15299 ] {a8d3a870-c7cb-4e15-bbae-7c6ba22f9d8d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'constant_value.value_' in scope SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_value.value_ SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:45.116336 [ 2854 ] {ca4ec402-775b-4aa7-835c-08d432cf1342} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40634) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:45.118582 [ 2854 ] {ca4ec402-775b-4aa7-835c-08d432cf1342} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:45.138600 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:45.212220 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:45.212762 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:45.407608 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:45.408135 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:45.576302 [ 2854 ] {e0960b4e-1253-45fc-8bc6-6a8e59f5725d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'constant_valu.value_' in scope SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_valu.value_ SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40660) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT cast(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_valu.value_ 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:45.578512 [ 2854 ] {e0960b4e-1253-45fc-8bc6-6a8e59f5725d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'constant_valu.value_' in scope SELECT CAST(tuple(1), 'Tuple(value_1 String)') AS constant_value, constant_valu.value_ SETTINGS enable_analyzer = 1. Maybe you meant: ['constant_value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:45.742816 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:45.745302 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:46.190693 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:46.193420 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:46.245218 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:46.342494 [ 12293 ] {c644fe90-9f43-4c1b-b180-6ca0fa1b5100} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'constant_value.value_' in scope lambda_argument -> (lambda_argument + constant_value.value_). Maybe you meant: ['constant_value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40704) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT cast(tuple(1), 'Tuple(value_1 String)') AS constant_value, arrayMap(lambda_argument -> lambda_argument + constant_value.value_, [1, 2, 3]) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000334c5e71 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033499545 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:46.344384 [ 12293 ] {c644fe90-9f43-4c1b-b180-6ca0fa1b5100} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'constant_value.value_' in scope lambda_argument -> (lambda_argument + constant_value.value_). Maybe you meant: ['constant_value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000334c5e71 9. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000033499545 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:10:46.969606 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:46.972580 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:47.186757 [ 2854 ] {85c7ed1f-2ec8-43d1-8a60-5fce6f762dda} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'constant_value.value_' in scope (SELECT constant_value.value_). Maybe you meant: ['constant_value.value_1']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40712) (comment: 02476_analyzer_identifier_hints.sh) (in query: WITH cast(tuple(1), 'Tuple(value_1 String)') AS constant_value SELECT (SELECT constant_value.value_) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343ef6d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 29. ? @ 0x00007f038ce47ac3 30. ? @ 0x00007f038ced9850 2025.03.31 19:10:47.188698 [ 2854 ] {85c7ed1f-2ec8-43d1-8a60-5fce6f762dda} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'constant_value.value_' in scope (SELECT constant_value.value_). Maybe you meant: ['constant_value.value_1']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343ef6d 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 11. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 23. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 27. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 28. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 29. ? @ 0x00007f038ce47ac3 30. ? @ 0x00007f038ced9850 2025.03.31 19:10:47.323954 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:47.528868 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:47.531840 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:48.325096 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:48.327707 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:48.356794 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:49.380517 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:49.509185 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:49.512368 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:50.445045 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:50.513125 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:50.513608 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:50.773398 [ 4240 ] {188b294b-c5b7-40a5-b04d-5b3d835d2b3c} executeQuery: Code: 47. DB::Exception: Identifier 'test_table_1.value_' cannot be resolved from table with name test_0i4nvr1d.test_table_1. In scope SELECT test_table_1.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_1.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40796) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_table_1.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b32c4 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d6a 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:50.775599 [ 4240 ] {188b294b-c5b7-40a5-b04d-5b3d835d2b3c} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table_1.value_' cannot be resolved from table with name test_0i4nvr1d.test_table_1. In scope SELECT test_table_1.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_1.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b32c4 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d6a 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:51.193081 [ 2854 ] {2c7a305b-7b3d-4b48-b22f-b2f28f0daed7} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:32948) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:51.195232 [ 2854 ] {2c7a305b-7b3d-4b48-b22f-b2f28f0daed7} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:51.253189 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:51.256003 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:51.498112 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:52.109441 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:52.112191 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:52.660842 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:52.699378 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:52.699778 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:53.080391 [ 2854 ] {b531e44c-6a42-4bb3-a588-8f5e0bc043fc} executeQuery: Code: 47. DB::Exception: Identifier 'test_table_2.value_' cannot be resolved from table with name test_0i4nvr1d.test_table_2. In scope SELECT test_table_2.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_2.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:32958) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT test_table_2.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1003: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b33a5 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d6a 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:53.082313 [ 2854 ] {b531e44c-6a42-4bb3-a588-8f5e0bc043fc} TCPHandler: Code: 47. DB::Exception: Identifier 'test_table_2.value_' cannot be resolved from table with name test_0i4nvr1d.test_table_2. In scope SELECT test_table_2.value_ FROM test_table_1 INNER JOIN test_table_2 ON test_table_1.id = test_table_2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['test_table_2.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1003: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b33a5 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d6a 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:53.665235 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:53.667967 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:53.729346 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:53.736988 [ 5368 ] {e072cbb2-f251-48e3-ac6c-48f656720c0b} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_1.t_async_insert_bad_data FORMAT Values' with query id 8a018d88-89dc-4df3-a264-1a9da5698aa4. DB::Exception: Cannot parse expression of type String here: 'bad'string') 2025.03.31 19:10:53.834772 [ 2854 ] {ae657b1e-f36f-4972-96b3-2f47b76022f6} executeQuery: Code: 47. DB::Exception: Identifier 't1.value_' cannot be resolved from table with name t1. In scope SELECT t1.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['t1.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33060) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT t1.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b32c4 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d6a 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:53.836935 [ 2854 ] {ae657b1e-f36f-4972-96b3-2f47b76022f6} TCPHandler: Code: 47. DB::Exception: Identifier 't1.value_' cannot be resolved from table with name t1. In scope SELECT t1.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['t1.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b32c4 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d6a 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:54.253016 [ 4187 ] {8a018d88-89dc-4df3-a264-1a9da5698aa4} executeQuery: Code: 62. DB::Exception: Cannot parse expression of type String here: 'bad'string'): While executing WaitForAsyncInsert. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58462) (comment: 02563_async_insert_bad_data.sh) (in query: INSERT INTO t_async_insert_bad_data VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity>>::type>, String&&, std::basic_string_view>&&) @ 0x000000001c70884d 4. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:434: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x000000003b6c45e1 5. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:0: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x000000003b6bde3a 6. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:0: DB::ValuesBlockInputFormat::read() @ 0x000000003b6ba683 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aeb5ab9 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae2c8d3 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aeb17cc 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aeb1133 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364cbe3 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365818f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:10:54.255692 [ 4187 ] {8a018d88-89dc-4df3-a264-1a9da5698aa4} DynamicQueryHandler: Code: 62. DB::Exception: Cannot parse expression of type String here: 'bad'string'): While executing WaitForAsyncInsert. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity>>::type>, String&&, std::basic_string_view>&&) @ 0x000000001c70884d 4. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:434: DB::ValuesBlockInputFormat::parseExpression(DB::IColumn&, unsigned long) @ 0x000000003b6c45e1 5. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:0: DB::ValuesBlockInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, unsigned long) @ 0x000000003b6bde3a 6. ./build_docker/./src/Processors/Formats/Impl/ValuesBlockInputFormat.cpp:0: DB::ValuesBlockInputFormat::read() @ 0x000000003b6ba683 7. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aeb5ab9 8. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae2c8d3 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 10. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:59: DB::StreamingFormatExecutor::execute() @ 0x000000003aeb17cc 11. ./build_docker/./src/Processors/Executors/StreamingFormatExecutor.cpp:42: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x000000003aeb1133 12. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x000000003364cbe3 13. ./build_docker/./src/Interpreters/AsynchronousInsertQueue.cpp:0: void std::__function::__policy_invoker::__call_impl>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000003365818f 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:54.415437 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:54.418091 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:54.658613 [ 2854 ] {9edfaea9-2efb-4645-8aaa-dae81fc11ad0} executeQuery: Code: 47. DB::Exception: Identifier 't2.value_' cannot be resolved from table with name t2. In scope SELECT t2.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['t2.value']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33074) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT t2.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1003: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b33a5 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d6a 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:54.661265 [ 2854 ] {9edfaea9-2efb-4645-8aaa-dae81fc11ad0} TCPHandler: Code: 47. DB::Exception: Identifier 't2.value_' cannot be resolved from table with name t2. In scope SELECT t2.value_ FROM test_table_1 AS t1 INNER JOIN test_table_2 AS t2 ON t1.id = t2.id SETTINGS enable_analyzer = 1. Maybe you meant: ['t2.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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 const&, String&, String&&, String&&) @ 0x00000000335c615f 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x00000000335adc34 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:944: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b12a6 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1483: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d38 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1003: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b33a5 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000335b7d6a 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x00000000335beee7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1396: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000003347399d 11. ./src/Analyzer/Resolve/IdentifierLookup.h:47: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000033440893 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:10:54.750064 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:54.839546 [ 4240 ] {576e75a2-b914-46d7-a6a8-44ea7b103e6f} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33090) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:54.841671 [ 4240 ] {576e75a2-b914-46d7-a6a8-44ea7b103e6f} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:10:55.487587 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:55.565622 [ 2854 ] {f665f2d4-7c45-49ef-822d-35aa2f2c2099} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'a.size1' in scope SELECT [1] AS a, a.size1 SETTINGS enable_analyzer = 1. Maybe you meant: ['a.size0']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33118) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT [1] AS a, a.size1 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:55.568039 [ 2854 ] {f665f2d4-7c45-49ef-822d-35aa2f2c2099} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'a.size1' in scope SELECT [1] AS a, a.size1 SETTINGS enable_analyzer = 1. Maybe you meant: ['a.size0']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:55.586461 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:55.791220 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:56.280919 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:56.284599 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:56.350597 [ 12293 ] {18144dfd-1958-4fe4-9488-12d06cac5029} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 't.c' in scope SELECT CAST('((1))', 'Tuple(a Tuple(b UInt32))') AS t, t.c SETTINGS enable_analyzer = 1. Maybe you meant: ['t.a']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33152) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT ((1))::Tuple(a Tuple(b UInt32)) AS t, t.c 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:56.352999 [ 12293 ] {18144dfd-1958-4fe4-9488-12d06cac5029} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 't.c' in scope SELECT CAST('((1))', 'Tuple(a Tuple(b UInt32))') AS t, t.c SETTINGS enable_analyzer = 1. Maybe you meant: ['t.a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:56.852086 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:57.074503 [ 15299 ] {0d5107c1-e46d-404c-805d-d24b00ae0d21} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 't.a.c' in scope SELECT CAST('((1))', 'Tuple(a Tuple(b UInt32))') AS t, t.a.c SETTINGS enable_analyzer = 1. Maybe you meant: ['t.a.b']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33188) (comment: 02476_analyzer_identifier_hints.sh) (in query: SELECT ((1))::Tuple(a Tuple(b UInt32)) AS t, t.a.c 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:57.076762 [ 15299 ] {0d5107c1-e46d-404c-805d-d24b00ae0d21} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 't.a.c' in scope SELECT CAST('((1))', 'Tuple(a Tuple(b UInt32))') AS t, t.a.c SETTINGS enable_analyzer = 1. Maybe you meant: ['t.a.b']. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:10:57.193266 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:57.194000 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:57.612729 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:57.615544 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:57.897427 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:58.637855 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:58.640602 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:59.020925 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:10:59.705641 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:10:59.706332 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:00.056662 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:00.057313 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:00.077208 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:00.432893 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:00.435445 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:00.866427 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:00.869018 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:01.172532 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:01.392641 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:01.395139 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:02.050340 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:02.052793 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:02.227397 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:02.892159 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:02.894836 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:03.347703 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:03.774136 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:03.777142 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:04.377523 [ 2854 ] {f9607291-8b04-4ab4-9c7a-792fd327c809} executeQuery: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 4295967296 microseconds: while executing 'FUNCTION sleep(4295.967296_Float64 :: 1) -> sleep(4295.967296_Float64) UInt8 : 2'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47572) (comment: 00833_sleep_overflow.sql) (in query: SELECT sleep(4295.967296);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x00000000083f0ded 4. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0b7438 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b5f11 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 18. ./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*) @ 0x000000003ae9f89d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:11:04.379025 [ 2854 ] {f9607291-8b04-4ab4-9c7a-792fd327c809} TCPHandler: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 4295967296 microseconds: while executing 'FUNCTION sleep(4295.967296_Float64 :: 1) -> sleep(4295.967296_Float64) UInt8 : 2'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x00000000083f0ded 4. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0b7438 5. DB::FunctionSleep<(DB::FunctionSleepVariant)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b5f11 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 14. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 18. ./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*) @ 0x000000003ae9f89d 19. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:11:04.387521 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:04.805897 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:04.806397 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:05.521554 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:05.570351 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:05.573692 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:05.907192 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:05.910341 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:06.573458 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:06.895656 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:06.896095 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:07.665990 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:08.041826 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:08.045580 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:08.723680 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:08.794208 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:08.810419 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:09.257306 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:09.257900 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:09.916249 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:10.313640 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:10.314201 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:10.871169 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:10.949969 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:11.024507 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:11.528767 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:11.529203 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:12.112553 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:12.436138 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:12.436644 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:12.875015 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:12.877501 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:12.946738 [ 19200 ] {bf21d506-da3f-4420-8e54-267dda86f57e} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47104) (comment: 02249_parse_date_time_basic.sql) (in query: CREATE TABLE t (a DateTime('UTC'), b String, c String, d String, e Int32) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:12.948850 [ 19200 ] {bf21d506-da3f-4420-8e54-267dda86f57e} TCPHandler: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:13.202352 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:13.895155 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:13.898135 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:14.193663 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:14.196399 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:14.250376 [ 19311 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:15.105045 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:15.108170 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:15.384171 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:15.485435 [ 2854 ] {e7dfa5e7-2c96-4452-bedb-410e46ffdf66} 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.10457.altinitytest (altinity build)) (from [::1]:47136) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:11:15.494316 [ 2854 ] {e7dfa5e7-2c96-4452-bedb-410e46ffdf66} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:11:16.061398 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:16.064232 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:16.467173 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:16.756472 [ 19260 ] {39cb28cf-958b-466a-9daa-c1f2214ba686} 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]:54286). (NETWORK_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54286) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c1518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ec297 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003abca095 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7c70 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:11:16.756472 [ 19142 ] {1a4f34a3-c0f4-4bf9-92fe-c87304d564c4} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:42852). (NETWORK_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42852) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c1518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ec297 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003abca095 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7c70 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:11:17.121570 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:17.124834 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:17.389455 [ 19142 ] {1a4f34a3-c0f4-4bf9-92fe-c87304d564c4} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:42852). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c1518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ec297 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003abe999a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abbb56a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab956a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:17.389454 [ 19260 ] {39cb28cf-958b-466a-9daa-c1f2214ba686} 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]:54286). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c1518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ec297 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003abe999a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abbb56a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab956a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:17.390057 [ 19142 ] {1a4f34a3-c0f4-4bf9-92fe-c87304d564c4} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:42852). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c1518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ec297 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003abca095 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7c70 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:11:17.390076 [ 19260 ] {39cb28cf-958b-466a-9daa-c1f2214ba686} 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]:54286). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c1518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ec297 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000003abca095 6. ./build_docker/./src/Server/TCPHandler.cpp:1165: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7c70 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:11:17.390708 [ 19142 ] {1a4f34a3-c0f4-4bf9-92fe-c87304d564c4} TCPHandler: Client has gone away. 2025.03.31 19:11:17.390809 [ 19260 ] {39cb28cf-958b-466a-9daa-c1f2214ba686} TCPHandler: Client has gone away. 2025.03.31 19:11:17.512877 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:17.761663 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:17.764890 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:18.076603 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:18.080060 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:18.499629 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:18.502914 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:18.582297 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:19.441613 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:19.444186 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:19.629649 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:20.488290 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:20.491148 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:20.659048 [ 2854 ] {aa9864e1-40b1-4162-b67b-ae966d0d796d} executeQuery: Code: 36. DB::Exception: Cannot DROP or CLEAR all columns. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47952) (comment: 01388_clear_all_columns.sql) (in query: ALTER TABLE test CLEAR COLUMN 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Storages/AlterCommands.cpp:1649: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809bf3a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348541d1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:20.659951 [ 2854 ] {aa9864e1-40b1-4162-b67b-ae966d0d796d} TCPHandler: Code: 36. DB::Exception: Cannot DROP or CLEAR all columns. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Storages/AlterCommands.cpp:1649: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000003809bf3a 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348541d1 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:20.705207 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:20.882349 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:20.885567 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:21.348480 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:21.349054 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:21.560574 [ 2854 ] {3383c103-59c9-4424-b621-17e10265d215} executeQuery: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47952) (comment: 01388_clear_all_columns.sql) (in query: ALTER TABLE test CLEAR COLUMN x IN PARTITION '';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000039764bad 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974c447 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:11:21.562060 [ 2854 ] {3383c103-59c9-4424-b621-17e10265d215} TCPHandler: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000039764bad 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974c447 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:11:21.579031 [ 2854 ] {97e94465-c7c6-4373-ad0a-7c7c21716cc7} executeQuery: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47952) (comment: 01388_clear_all_columns.sql) (in query: ALTER TABLE test CLEAR COLUMN x IN PARTITION 'asdasd';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000039764bad 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974c447 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:11:21.580166 [ 2854 ] {97e94465-c7c6-4373-ad0a-7c7c21716cc7} TCPHandler: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000039764bad 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974c447 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:11:21.643780 [ 2854 ] {f22db762-5745-4ad7-bc94-3d4c10d5537f} executeQuery: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_VALUE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47952) (comment: 01388_clear_all_columns.sql) (in query: ALTER TABLE test CLEAR COLUMN x IN PARTITION '123';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000039764bad 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974c447 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:11:21.644896 [ 2854 ] {f22db762-5745-4ad7-bc94-3d4c10d5537f} TCPHandler: Code: 248. DB::Exception: Wrong number of fields in the partition expression: 1, must be: 0. (INVALID_PARTITION_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5912: DB::MergeTreeData::getPartitionIDFromQuery(std::shared_ptr const&, std::shared_ptr, DB::DataPartsLock*) const @ 0x0000000039764bad 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003974c447 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:11:21.749483 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:22.006932 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:22.009315 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:22.515787 [ 2854 ] {17a89ac8-b40b-46ce-9f73-24693f4965ae} executeQuery: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47952) (comment: 01388_clear_all_columns.sql) (in query: ALTER TABLE test CLEAR COLUMN y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x00000000398ab0f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3623: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975344b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:22.516822 [ 2854 ] {17a89ac8-b40b-46ce-9f73-24693f4965ae} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are not allowed. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x00000000398ab0f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3623: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975344b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:22.564109 [ 2854 ] {6915df9c-0d9b-4d10-9721-8328f58461da} executeQuery: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are not allowed. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47952) (comment: 01388_clear_all_columns.sql) (in query: -- y is only real column in table ALTER TABLE test CLEAR COLUMN y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x00000000398ab0f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3623: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975344b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:22.565050 [ 2854 ] {6915df9c-0d9b-4d10-9721-8328f58461da} TCPHandler: Code: 36. DB::Exception: Cannot drop or clear column 'y', because all columns in part 'all_1_1_0_2' will be removed from disk. Empty parts are not allowed. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x00000000398ab0f7 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3623: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000003975344b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854295 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:22.815982 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:23.056340 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:23.131360 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:23.368547 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:23.371787 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:23.693070 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:23.693498 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:23.959741 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:24.158181 [ 12294 ] {e94631ad-cd5a-4952-a597-fdcf12e685d0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=728). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45384) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 13595045;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:24.161223 [ 12294 ] {e94631ad-cd5a-4952-a597-fdcf12e685d0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=728). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:24.339721 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:24.340294 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:24.994868 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:24.997549 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:25.002152 [ 19203 ] {5f2eaed6-9770-4fea-aba9-85b1ba174d76} executeQuery: Code: 48. DB::Exception: DELETE query is not supported for table test_1.users as it has projections. User should drop all the projections manually before running the query. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48014) (comment: 03161_lightweight_delete_projection.sql) (in query: DELETE FROM users 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:128: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a6be06 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:11:25.003136 [ 19203 ] {5f2eaed6-9770-4fea-aba9-85b1ba174d76} TCPHandler: Code: 48. DB::Exception: DELETE query is not supported for table test_1.users as it has projections. User should drop all the projections manually before running the query. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:128: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a6be06 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:11:25.015801 [ 19203 ] {859259f7-c5c4-4861-8851-aab0ef3c1525} executeQuery: Code: 48. DB::Exception: DELETE query is not supported for table test_1.users as it has projections. User should drop all the projections manually before running the query. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48014) (comment: 03161_lightweight_delete_projection.sql) (in query: DELETE FROM users WHERE uid = 8888 SETTINGS lightweight_mutation_projection_mode = 'throw';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:128: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a6be06 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:11:25.017043 [ 19203 ] {859259f7-c5c4-4861-8851-aab0ef3c1525} TCPHandler: Code: 48. DB::Exception: DELETE query is not supported for table test_1.users as it has projections. User should drop all the projections manually before running the query. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:128: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a6be06 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:11:25.216439 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:25.320900 [ 3602 ] {f7871e45-c72b-449c-8f1e-47295de00ad6::all_3_3_0_6} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:25.321432 [ 3602 ] {f7871e45-c72b-449c-8f1e-47295de00ad6::all_3_3_0_6} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:25.372529 [ 3598 ] {f7871e45-c72b-449c-8f1e-47295de00ad6::all_1_1_0_6} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:25.373046 [ 3598 ] {f7871e45-c72b-449c-8f1e-47295de00ad6::all_1_1_0_6} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:25.607955 [ 19200 ] {b1b77226-b59f-4ca0-af69-7fb26f4c9ca9} 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.10457.altinitytest (altinity build)) (from [::1]:48032) (comment: 00172_hits_joins.gen.sql) (in query: SELECT CounterID, hits, visits FROM ( SELECT (CounterID % 100000) AS CounterID, count() AS hits FROM test.hits GROUP BY CounterID ) ANY LEFT 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 SETTINGS any_join_distinct_right_table_keys = 1, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:11:25.613430 [ 19200 ] {b1b77226-b59f-4ca0-af69-7fb26f4c9ca9} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:11:25.907383 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:25.910821 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:26.143412 [ 19203 ] {0966ec3f-dcf8-4824-b9fb-03c9f0e2fede} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_6.txt' with part 'all_3_3_0_5' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48014) (comment: 03161_lightweight_delete_projection.sql) (in query: DELETE FROM users WHERE uid = 6666 SETTINGS lightweight_mutation_projection_mode = 'drop';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfc29f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfc005 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x0000000035a6e6e3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a6aa8c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:11:26.144716 [ 19203 ] {0966ec3f-dcf8-4824-b9fb-03c9f0e2fede} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_6.txt' with part 'all_3_3_0_5' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfc29f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfc005 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./src/Interpreters/InterpreterAlterQuery.h:18: DB::InterpreterDeleteQuery::execute()::$_0::operator()() const @ 0x0000000035a6e6e3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDeleteQuery::execute() @ 0x0000000035a6aa8c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:11:26.243497 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:26.603199 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:26.604779 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039d03d22 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f91bf1 19. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000034f9c58b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e68dd2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aa57c 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:27.113544 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:27.116522 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:27.286118 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:27.827890 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:27.830506 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:28.334072 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:28.475857 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:28.478780 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:28.564449 [ 4240 ] {d0f8df94-6a38-4f65-9ad4-b5aa16451978} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 15.: In scope SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- MIN, MAX AND FAMILY should check for errors in its input SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1163: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000002cf0ac0c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:136: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ceba50f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:28.565688 [ 4240 ] {d0f8df94-6a38-4f65-9ad4-b5aa16451978} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 15.: In scope SELECT finalizeAggregation(CAST(unhex('0F00000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1163: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000002cf0ac0c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:136: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ceba50f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:28.582765 [ 4240 ] {1749a347-2c45-4878-b62f-232279fe3e63} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 65535.: In scope SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1163: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000002cf0ac0c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:136: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ceba50f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:28.583877 [ 4240 ] {1749a347-2c45-4878-b62f-232279fe3e63} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 1. Bytes expected: 65535.: In scope SELECT finalizeAggregation(CAST(unhex('FFFF000030'), 'AggregateFunction(min, String)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/SingleValueData.cpp:1163: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, DB::Arena*) @ 0x000000002cf0ac0c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:136: DB::(anonymous namespace)::AggregateFunctionMinMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ceba50f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:29.163509 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:29.166770 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:29.439214 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:30.128226 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:30.130551 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:30.428472 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:30.488610 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:30.780765 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d6e01 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:30.793304 [ 4240 ] {2aa53478-40b8-4845-a7e1-e8899a310eb2} executeQuery: Code: 32. DB::Exception: Attempt to read after eof: In scope SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)')). (ATTEMPT_TO_READ_AFTER_EOF) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- aggThrow should check for errors in its input SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. DB::ReadBuffer::throwReadAfterEOF() @ 0x000000000b5f2f0c 5. ./src/IO/BufferBase.h:99: DB::(anonymous namespace)::AggregateFunctionThrow::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f5ffb61 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:30.794525 [ 4240 ] {2aa53478-40b8-4845-a7e1-e8899a310eb2} TCPHandler: Code: 32. DB::Exception: Attempt to read after eof: In scope SELECT finalizeAggregation(CAST('', 'AggregateFunction(aggThrow(0.), UInt8)')). (ATTEMPT_TO_READ_AFTER_EOF), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. DB::ReadBuffer::throwReadAfterEOF() @ 0x000000000b5f2f0c 5. ./src/IO/BufferBase.h:99: DB::(anonymous namespace)::AggregateFunctionThrow::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f5ffb61 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:31.411526 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:31.414428 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:31.701477 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:32.289901 [ 4240 ] {9db34843-a615-48fc-b812-958c3a55fd83} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 16. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- categoricalInformationValue should check for errors in its input SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:122: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f5f2f75 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:32.291228 [ 4240 ] {9db34843-a615-48fc-b812-958c3a55fd83} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 16. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('01000000000000000100000000000000'), 'AggregateFunction(categoricalInformationValue, UInt8, UInt8)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:122: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f5f2f75 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:32.485078 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:32.488014 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:32.794874 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:33.664300 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:33.667011 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:33.859480 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:34.325475 [ 4240 ] {d4922ee7-8a31-4bb8-9af9-544de68f04a3} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 31. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:122: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f5f2f75 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd98ac7 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:34.326824 [ 4240 ] {d4922ee7-8a31-4bb8-9af9-544de68f04a3} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 31. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('0101000000000000000100000000000000020000000000000001000000000000'), 'AggregateFunction(categoricalInformationValue, Nullable(UInt8), UInt8)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionCategoricalInformationValue.cpp:122: DB::AggregateFunctionCategoricalIV::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f5f2f75 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd98ac7 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:34.441190 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:34.443596 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:34.878983 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:35.330622 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:35.331134 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:35.930652 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:36.163844 [ 3830 ] {b975979e-d599-4678-a8f1-5b38c7e20df3} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness RightAny. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35390) (comment: 00063_loyalty_joins.sql) (in query: SELECT loyalty, count() FROM test.hits ANY LEFT JOIN ( SELECT UserID, sum(SearchEngineID = 2) AS yandex, sum(SearchEngineID = 3) AS google, toInt8(if(yandex > google, yandex / (yandex + google), -google / (yandex + google)) * 10) AS loyalty FROM test.hits WHERE (SearchEngineID = 2) OR (SearchEngineID = 3) GROUP BY UserID HAVING (yandex + google) > 10 ) USING UserID GROUP BY loyalty ORDER BY loyalty ASC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b85092a 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) @ 0x000000003b82e89a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b82f592 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b84ea71 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&) @ 0x00000000322a7a0f 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>>*) @ 0x000000003228ccb4 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be2e6fe 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 2025.03.31 19:11:36.166336 [ 3830 ] {b975979e-d599-4678-a8f1-5b38c7e20df3} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000003b85092a 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) @ 0x000000003b82e89a 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000003b82f592 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000003b84ea71 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&) @ 0x00000000322a7a0f 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>>*) @ 0x000000003228ccb4 9. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be2e6fe 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 2025.03.31 19:11:36.185251 [ 4240 ] {afc84f9e-5a51-4ab2-9e51-3276fc3cc095} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 4. Bytes expected: 6271.: In scope SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- groupArray should check for errors in its input SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:421: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002b116562 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:684: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002b198797 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:36.186882 [ 4240 ] {afc84f9e-5a51-4ab2-9e51-3276fc3cc095} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 4. Bytes expected: 6271.: In scope SELECT finalizeAggregation(CAST(unhex('5FF3001310132'), 'AggregateFunction(groupArray, String)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:421: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002b116562 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:684: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002b198797 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:36.416899 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:36.419811 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:36.964104 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:37.531505 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:37.533892 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:37.777056 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:37.777527 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:37.895240 [ 4240 ] {3bb83fcf-79b8-4543-b597-3005f937b1b6} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 23. Bytes expected: 1016.: In scope SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:351: DB::(anonymous namespace)::GroupArrayNumericImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002b147fe6 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:37.896446 [ 4240 ] {3bb83fcf-79b8-4543-b597-3005f937b1b6} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 23. Bytes expected: 1016.: In scope SELECT finalizeAggregation(CAST(unhex('FF000000000000000001000000000000000200000000000000'), 'AggregateFunction(groupArray, UInt64)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:351: DB::(anonymous namespace)::GroupArrayNumericImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002b147fe6 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:37.996543 [ 19311 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:38.092139 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:38.093661 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039d03d22 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f91bf1 19. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000034f9c58b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e68dd2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aa57c 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:39.053200 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:39.424751 [ 4240 ] {cdc8ebad-df68-434c-bcaf-3fe1421c8065} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- Same for groupArrayMovingXXXX SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./src/Common/PODArray.h:316: DB::MovingImpl, DB::MovingSumData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f39c8dc 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:39.426267 [ 4240 ] {cdc8ebad-df68-434c-bcaf-3fe1421c8065} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingSum, UInt64)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./src/Common/PODArray.h:316: DB::MovingImpl, DB::MovingSumData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f39c8dc 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:39.441017 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:39.444921 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:40.091428 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:40.216380 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:40.219629 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:40.720393 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:40.720845 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:41.032578 [ 4240 ] {cd54310f-dadf-4157-bd83-8a334ee48b5e} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./src/Common/PODArray.h:316: DB::MovingImpl, DB::MovingAvgData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f4e744a 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:41.036399 [ 4240 ] {cd54310f-dadf-4157-bd83-8a334ee48b5e} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 24. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0FF00000000000000001000000000000000300000000000000'), 'AggregateFunction(groupArrayMovingAvg, UInt64)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./src/Common/PODArray.h:316: DB::MovingImpl, DB::MovingAvgData>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f4e744a 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:41.125167 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:41.417132 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:41.417701 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:42.121917 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:42.124554 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:42.196813 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:42.372085 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:42.374585 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:42.790741 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:42.791357 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:43.232848 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:43.404000 [ 4240 ] {1fa83ecb-80c9-4e45-85b6-7eb96791e954} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 46. Bytes expected: 80.: In scope SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- Histogram SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:310: DB::(anonymous namespace)::AggregateFunctionHistogramData::read(DB::ReadBuffer&, unsigned int) @ 0x000000002f23868e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:370: DB::(anonymous namespace)::AggregateFunctionHistogram::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f26f509 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:43.405063 [ 4240 ] {1fa83ecb-80c9-4e45-85b6-7eb96791e954} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 46. Bytes expected: 80.: In scope SELECT finalizeAggregation(CAST(unhex('00000000000024C000000000000018C00500000000000024C0000000000000F03F00000000000022C0000000000000F03F00000000000020C0000000000000'), 'AggregateFunction(histogram(5), Int64)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:310: DB::(anonymous namespace)::AggregateFunctionHistogramData::read(DB::ReadBuffer&, unsigned int) @ 0x000000002f23868e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionHistogram.cpp:370: DB::(anonymous namespace)::AggregateFunctionHistogram::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f26f509 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:43.427969 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:43.430657 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:43.535657 [ 19260 ] {e823578a-4736-41b1-8a8d-0a4cfdf2dfcf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=728). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45928) (comment: 00072_compare_date_and_string_index.sql) (in query: SELECT count() FROM test.hits_indexed_by_time WHERE EventTime = '2014-03-18 01:02:03';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:43.538726 [ 19260 ] {e823578a-4736-41b1-8a8d-0a4cfdf2dfcf} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=728). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:44.208302 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:44.210906 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:44.340529 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:45.230804 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:45.231282 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:45.380929 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:45.804422 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:45.806853 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:45.848645 [ 4240 ] {7ec2e675-d3c9-465a-8d4e-7ec177467748} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 56. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- StatisticalSample SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./src/Common/PODArray.h:315: DB::StatisticalSample::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f60671c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:229: DB::(anonymous namespace)::AggregateFunctionMannWhitney::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f612a52 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:45.850580 [ 4240 ] {7ec2e675-d3c9-465a-8d4e-7ec177467748} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 56. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F01000000000000244000000000000026400000000000002840000000000000244000000000000026400000000000002840000000000000F03F'), 'AggregateFunction(mannWhitneyUTest, Float64, UInt8)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./src/Common/PODArray.h:315: DB::StatisticalSample::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f60671c 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionMannWhitney.cpp:229: DB::(anonymous namespace)::AggregateFunctionMannWhitney::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f612a52 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:46.422343 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:46.672298 [ 3610 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fce196b8-b32c-4319-8cdf-3d340eb025b8::202503_1_218_19}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:46.725308 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:46.725990 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:47.235000 [ 4240 ] {c5bb2fe3-a751-455f-a674-9afed386304a} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 64. Bytes expected: 240.: In scope SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- maxIntersections SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:155: DB::(anonymous namespace)::AggregateFunctionIntersectionsMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f1951fa 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:47.236456 [ 4240 ] {c5bb2fe3-a751-455f-a674-9afed386304a} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 64. Bytes expected: 240.: In scope SELECT finalizeAggregation(CAST(unhex('0F010000000000000001000000000000000300000000000000FFFFFFFFFFFFFFFF03340B9B047F000001000000000000000500000065000000FFFFFFFFFFFFFFFF'), 'AggregateFunction(maxIntersections, UInt8, UInt8)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionMaxIntersections.cpp:155: DB::(anonymous namespace)::AggregateFunctionIntersectionsMax::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f1951fa 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:47.548980 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:47.780701 [ 19203 ] {05fe27db-bd01-457e-83e9-0d08b2c85483} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46076) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:11:47.782795 [ 19203 ] {05fe27db-bd01-457e-83e9-0d08b2c85483} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:11:47.849575 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:47.850256 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:47.891541 [ 19200 ] {a0cd6b27-71cd-4dc5-8bfa-77304c527026} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46072) (comment: 00176_distinct_limit_by_limit_bug_43377.sql) (in query: SELECT count() FROM ( SELECT DISTINCT Title, SearchPhrase FROM test.hits WHERE (SearchPhrase != '') AND (NOT match(Title, '[а-яА-ЯёЁ]')) AND (NOT match(SearchPhrase, '[а-яА-ЯёЁ]')) LIMIT 1 BY Title 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:11:47.895184 [ 19200 ] {a0cd6b27-71cd-4dc5-8bfa-77304c527026} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:11:48.456998 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:48.457563 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:48.592590 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:48.934314 [ 4240 ] {2218dabd-300a-4edc-bf04-cecb2aff570f} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- sequenceNextNode (This was fine because it would fail in the next readBinary call, but better to add a test) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(''forward'', ''head''), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions=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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:103: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63c284 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f6471ba 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd98ac7 8. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 10. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 23. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 26. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 2025.03.31 19:11:48.936172 [ 4240 ] {2218dabd-300a-4edc-bf04-cecb2aff570f} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:103: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63c284 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f6471ba 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd98ac7 8. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 10. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 23. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 26. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 2025.03.31 19:11:49.077806 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:49.080984 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:49.587966 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:49.591236 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:49.661768 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:50.154708 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:50.158467 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:50.720000 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:50.843018 [ 4240 ] {b7838c8f-bfa1-4117-9440-1e9aa987eadf} executeQuery: Code: 128. DB::Exception: Too large node state size: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- Fuzzer (ALL) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:97: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63c4eb 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f6471ba 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd98ac7 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:50.845086 [ 4240 ] {b7838c8f-bfa1-4117-9440-1e9aa987eadf} TCPHandler: Code: 128. DB::Exception: Too large node state size: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:97: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63c4eb 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f6471ba 6. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd98ac7 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:50.869906 [ 4240 ] {81100165-04f1-4294-9421-115f40bae71a} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- Fuzzer 2 (UBSAN) SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:103: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63c284 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f6471ba 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd98ac7 8. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 10. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 23. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 26. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 2025.03.31 19:11:50.871839 [ 4240 ] {81100165-04f1-4294-9421-115f40bae71a} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 44. Bytes expected: 65.: In scope SELECT finalizeAggregation(CAST(unhex('FFFFFFF014181056F38010000000000000001FFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFFF'), 'AggregateFunction(sequenceNextNode(\'forward\', \'head\'), DateTime, Nullable(String), UInt8, Nullable(UInt8))')) SETTINGS allow_experimental_funnel_functions = 1. (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:103: DB::(anonymous namespace)::NodeBase, 64ul>::read(DB::ReadBuffer&, DB::Arena*) @ 0x000000002f63c284 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionSequenceNextNode.cpp:341: DB::(anonymous namespace)::SequenceNextNodeImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002f6471ba 7. ./src/AggregateFunctions/Combinators/AggregateFunctionNull.h:190: DB::AggregateFunctionNullBase>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002fd98ac7 8. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 9. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 10. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 20. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 23. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 26. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 28. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 29. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 31. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 2025.03.31 19:11:50.936893 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:50.939679 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:51.799304 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:52.053690 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:52.056521 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:52.653152 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:52.754054 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:52.921916 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:52.922151 [ 4240 ] {29817766-0a7b-46c4-8216-fa479c332456} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- uniqUpTo SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:223: DB::(anonymous namespace)::AggregateFunctionUniqUpTo::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ed4bca7 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:52.924184 [ 4240 ] {29817766-0a7b-46c4-8216-fa479c332456} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 32.: In scope SELECT finalizeAggregation(CAST(unhex('04128345AA2BC97190'), 'AggregateFunction(uniqUpTo(10), String)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionUniqUpTo.cpp:223: DB::(anonymous namespace)::AggregateFunctionUniqUpTo::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ed4bca7 6. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 8. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 9. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 10. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 11. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 18. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 21. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 2025.03.31 19:11:53.824305 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:53.827184 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:54.047431 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:54.709990 [ 4240 ] {9820dce4-edc3-4f61-9689-c746738cbfa8} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: -- quantiles SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./src/AggregateFunctions/QuantileExact.h:65: DB::QuantileExactBase>::deserialize(DB::ReadBuffer&) @ 0x000000002ba6788a 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileExact, false, void, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ba620af 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:54.711437 [ 4240 ] {9820dce4-edc3-4f61-9689-c746738cbfa8} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F0000000000000000'), 'AggregateFunction(quantileExact, UInt64)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./src/AggregateFunctions/QuantileExact.h:65: DB::QuantileExactBase>::deserialize(DB::ReadBuffer&) @ 0x000000002ba6788a 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileExact, false, void, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002ba620af 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:54.808532 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:54.811701 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:55.106210 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:55.842167 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:55.846146 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:56.207504 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:56.828362 [ 19204 ] {01fe846e-0585-4451-a7fd-fe36cadb9ae8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=728). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35846) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 30489182;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:56.832278 [ 19204 ] {01fe846e-0585-4451-a7fd-fe36cadb9ae8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=728). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:57.055998 [ 4240 ] {9c822e45-8ade-4f67-92ec-408382db1fa8} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)')). (CANNOT_READ_ALL_DATA) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48060) (comment: 02477_invalid_reads.sql) (in query: SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./src/Common/PODArray.h:315: DB::QuantileTDigest::deserialize(DB::ReadBuffer&) @ 0x000000002c58994a 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTDigest, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002c57d32f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:57.057379 [ 4240 ] {9c822e45-8ade-4f67-92ec-408382db1fa8} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 8. Bytes expected: 120.: In scope SELECT finalizeAggregation(CAST(unhex('0F000000000000803F'), 'AggregateFunction(quantileTDigest, UInt64)')). (CANNOT_READ_ALL_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000962e22d 4. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000962e0a7 5. ./src/Common/PODArray.h:315: DB::QuantileTDigest::deserialize(DB::ReadBuffer&) @ 0x000000002c58994a 6. ./src/AggregateFunctions/AggregateFunctionQuantile.h:248: DB::AggregateFunctionQuantile, DB::NameQuantileTDigest, false, float, false, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x000000002c57d32f 7. ./src/Common/PODArray.h:427: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x000000003264e563 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x000000003264ed7c 9. DB::(anonymous namespace)::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x00000000086e50f0 10. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, DB::DataTypeAggregateFunction const*) const::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x0000000009004380 11. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000086cbb34 12. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000841eb22 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 15. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 16. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd27f 17. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 19. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 22. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 25. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034ce03e4 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000034cd7a2e 31. ./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&) @ 0x0000000034ce2e55 2025.03.31 19:11:57.105676 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:57.111311 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:57.368477 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:57.750677 [ 19203 ] {38f653fe-0a26-454d-b8c8-f284f753611d} executeQuery: Code: 57. DB::Exception: Table test.hits_1m already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35938) (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 = 56088, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.050867218524217606, replace_long_file_name_to_hash = false, max_file_name_length = 74, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 470002907, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 7508624, merge_max_block_size = 9098, old_parts_lifetime = 248., 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 = 10737418240, index_granularity_bytes = 26939830, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 49500, primary_key_compress_block_size = 86742), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:57.755283 [ 19203 ] {38f653fe-0a26-454d-b8c8-f284f753611d} TCPHandler: Code: 57. DB::Exception: Table test.hits_1m 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:11:57.775639 [ 19200 ] {94fbc8f4-22fc-476e-ad85-4b1d3607ecee} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35954) (comment: 02962_analyzer_constant_set.sql) (in query: CREATE TABLE test_parallel_index (`z` UInt64, INDEX i z TYPE set(8) GRANULARITY 1) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 63189, min_bytes_for_wide_part = 967555247, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 34, min_bytes_for_full_part_storage = 361203645, compact_parts_max_bytes_to_buffer = 497008297, compact_parts_max_granules_to_buffer = 48, compact_parts_merge_max_bytes_to_prefetch_part = 28599558, merge_max_block_size = 18235, old_parts_lifetime = 179., 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 = 1037140450, index_granularity_bytes = 21649144, concurrent_part_removal_threshold = 48, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 85490, primary_key_compress_block_size = 68409), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 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>) @ 0x000000003a2c1d8a 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>&&) @ 0x000000003a2bfe8f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:11:57.778023 [ 19200 ] {94fbc8f4-22fc-476e-ad85-4b1d3607ecee} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 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>) @ 0x000000003a2c1d8a 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>&&) @ 0x000000003a2bfe8f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:11:57.950298 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:57.953344 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:58.468279 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:58.906044 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:58.909590 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:59.534129 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:59.538308 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:11:59.627904 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:11:59.824043 [ 12293 ] {75ae8eef-857c-40ac-91c3-8174908df23c} executeQuery: Code: 36. DB::Exception: Bidirectional can only be applied to hierarchical attributes. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35972) (comment: 02294_dictionaries_hierarchical_index.sql) (in query: CREATE DICTIONARY hierarchy_flat_dictionary_index ( id UInt64, parent_id UInt64 BIDIRECTIONAL ) PRIMARY KEY id SOURCE(CLICKHOUSE(TABLE 'test_hierarchy_source_table')) LAYOUT(FLAT()) LIFETIME(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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:0: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x00000000306c57f8 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:0: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x00000000306ba831 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:210: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000003478709c 7. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000003823f09f 8. ./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&) @ 0x000000003824c98a 9. ./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&) @ 0x000000003824c683 10. ./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&) @ 0x00000000382480e0 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382ef4c6 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:11:59.826405 [ 12293 ] {75ae8eef-857c-40ac-91c3-8174908df23c} TCPHandler: Code: 36. DB::Exception: Bidirectional can only be applied to hierarchical attributes. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:0: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x00000000306c57f8 5. ./build_docker/./src/Dictionaries/DictionaryStructure.cpp:0: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x00000000306ba831 6. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:210: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x000000003478709c 7. ./build_docker/./src/Storages/StorageDictionary.cpp:0: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x000000003823f09f 8. ./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&) @ 0x000000003824c98a 9. ./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&) @ 0x000000003824c683 10. ./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&) @ 0x00000000382480e0 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382ef4c6 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:11:59.991670 [ 4187 ] {ade2ce7d-931c-4076-9a46-9c87ef7e8ea7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33500) (comment: 02476_analyzer_identifier_hints.sh) (in query: DROP DATABASE IF EXISTS test_0i4nvr1d ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:11:59.995062 [ 4187 ] {ade2ce7d-931c-4076-9a46-9c87ef7e8ea7} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:00.208790 [ 12293 ] {4cd1a1fe-0a79-491d-a312-0b6fb3bca88d} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35972) (comment: 02294_dictionaries_hierarchical_index.sql) (in query: DROP DICTIONARY hierarchy_flat_dictionary_index;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:12:00.210046 [ 12293 ] {4cd1a1fe-0a79-491d-a312-0b6fb3bca88d} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:12:00.515540 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:00.516142 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:00.779586 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:01.808260 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:01.811496 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:01.987687 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:02.114392 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:02.115052 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:03.094889 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:03.293668 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:03.300711 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:04.092318 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:04.096167 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:04.181089 [ 19311 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:04.730050 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:04.733407 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:05.046165 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:05.046836 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:05.288735 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:05.763668 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:05.768419 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:06.254619 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:06.259072 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:06.575911 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:07.262462 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:07.265948 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:07.512009 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:07.516210 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:07.715273 [ 19311 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:07.893135 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:07.894241 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:08.872625 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:08.876166 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:08.955644 [ 19311 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:09.034484 [ 15299 ] {e256c794-13a2-489a-bf9b-c503669f06ed} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50518) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae5cf59 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:12:09.040607 [ 15299 ] {e256c794-13a2-489a-bf9b-c503669f06ed} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae5cf59 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:12:09.483053 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:09.486391 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:10.073588 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:10.303677 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:10.307430 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:11.074592 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:11.075174 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:11.198752 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:11.621211 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:11.699382 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:12.239158 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:12.354266 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:12.354878 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:12.893615 [ 19311 ] {5c110705-1fca-43a3-ba62-4629ea4bd38a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:32934) (comment: 00612_pk_in_tuple.sql) (in query: select * from tab_00612 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:12:12.896921 [ 19311 ] {5c110705-1fca-43a3-ba62-4629ea4bd38a} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:12:12.966554 [ 19199 ] {e1d44b66-9514-431a-92e2-d63a430fe2f6} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:32904) (comment: 01910_view_dictionary.sql) (in query: DROP DICTIONARY flat_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:12:12.968655 [ 19199 ] {e1d44b66-9514-431a-92e2-d63a430fe2f6} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:12:13.105874 [ 19288 ] {cdfc7719-bd8a-46ab-b4e9-13cf91306dee} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55300) (comment: 01910_view_dictionary.sql) (in query: DROP DATABASE IF EXISTS test_61iamcsw ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:12:13.107906 [ 19288 ] {cdfc7719-bd8a-46ab-b4e9-13cf91306dee} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 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>>>&) @ 0x000000003493136d 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:13.290398 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:13.364469 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:13.365662 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039d03d22 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f91bf1 19. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000034f9c58b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e68dd2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aa57c 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:13.714218 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:13.717431 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:14.219451 [ 19142 ] {9246c3ec-cb2b-4e4f-abc6-d99b8b16facd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=25, jobs=25). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:32962) (comment: 01671_aggregate_function_group_bitmap_data.sql) (in query: SELECT bitmapCardinality(day_today) AS today_users, bitmapCardinality(day_before) AS before_users, bitmapCardinality(bitmapOr(day_today, day_before)) AS ll_users, bitmapCardinality(bitmapAnd(day_today, day_before)) AS old_users, bitmapCardinality(bitmapAndnot(day_today, day_before)) AS new_users, bitmapCardinality(bitmapXor(day_today, day_before)) AS diff_users FROM ( SELECT city_id, groupBitmapState(uid) AS day_today FROM group_bitmap_data_test WHERE pickup_date = '2019-01-02' GROUP BY uid, city_id ) AS js1 ALL LEFT JOIN ( SELECT city_id, groupBitmapState(uid) AS day_before FROM group_bitmap_data_test WHERE pickup_date = '2019-01-01' GROUP BY city_id ) AS js2 USING (city_id) ORDER BY today_users, before_users, ll_users, old_users, new_users, diff_users;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:12:14.244344 [ 19142 ] {9246c3ec-cb2b-4e4f-abc6-d99b8b16facd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=25, jobs=25). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:12:14.330684 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:14.571111 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:14.571620 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:15.063111 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:15.067602 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:15.312169 [ 15299 ] {015d376e-467b-4cc3-8aa3-d5eb0818d89b} executeQuery: Code: 422. DB::Exception: Unsupported scheme in URI '/': The data format cannot be detected by the contents of the files. You can specify the format manually. (UNSUPPORTED_URI_SCHEME) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:32964) (comment: 01030_storage_url_syntax.sql) (in query: create table test_table_url_syntax (id UInt32) ENGINE = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Common/HTTPConnectionPool.cpp:837: DB::HTTPConnectionPools::Impl::useSecureConnection(Poco::URI const&, DB::ProxyConfiguration const&) @ 0x000000002072c6b1 5. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::HTTPConnectionPools::Impl::getPoolImpl(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000020722454 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::HTTPConnectionPools::Impl::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000020720f72 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:883: DB::HTTPConnectionPools::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000020720c43 8. ./build_docker/./src/IO/HTTPCommon.cpp:59: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&) @ 0x0000000020973f1a 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:265: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bae2a3 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bae915 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb05f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bb7761 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020ba933f 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb3e3c 15. DB::ReadBuffer::next() @ 0x00000000095afaaf 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bad51a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9c146 18. ./src/IO/ReadWriteBufferFromHTTP.h:242: DB::StorageURLSource::getFirstAvailableURIAndReadBuffer(std::__wrap_iter&, std::__wrap_iter const&, std::shared_ptr, std::vector, std::allocator>> const&, String const&, std::function>&)>, DB::ConnectionTimeouts const&, Poco::Net::HTTPBasicCredentials&, std::vector> const&, bool, bool) @ 0x0000000038c6845e 19. ./build_docker/./src/Storages/StorageURL.cpp:799: DB::(anonymous namespace)::ReadBufferIterator::next() @ 0x0000000038c86e3d 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad6f75a 21. ./contrib/llvm-project/libcxx/include/optional:260: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad81c9e 22. ./build_docker/./src/Storages/StorageURL.cpp:0: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x0000000038c6e516 23. ./contrib/llvm-project/libcxx/include/optional:260: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c5dcaa 24. ./build_docker/./src/Storages/StorageURL.cpp:1380: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c7951c 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageURL* std::construct_at[abi:v15007], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca51fb 26. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca4e29 27. ./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&) @ 0x0000000038c95d14 28. ./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 @ 0x00000000382ef4c6 29. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 2025.03.31 19:12:15.313655 [ 15299 ] {015d376e-467b-4cc3-8aa3-d5eb0818d89b} TCPHandler: Code: 422. DB::Exception: Unsupported scheme in URI '/': The data format cannot be detected by the contents of the files. You can specify the format manually. (UNSUPPORTED_URI_SCHEME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Common/HTTPConnectionPool.cpp:837: DB::HTTPConnectionPools::Impl::useSecureConnection(Poco::URI const&, DB::ProxyConfiguration const&) @ 0x000000002072c6b1 5. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::HTTPConnectionPools::Impl::getPoolImpl(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000020722454 6. ./build_docker/./src/Common/HTTPConnectionPool.cpp:0: DB::HTTPConnectionPools::Impl::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000020720f72 7. ./build_docker/./src/Common/HTTPConnectionPool.cpp:883: DB::HTTPConnectionPools::getPool(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ProxyConfiguration const&) @ 0x0000000020720c43 8. ./build_docker/./src/IO/HTTPCommon.cpp:59: DB::makeHTTPSession(DB::HTTPConnectionGroupType, Poco::URI const&, DB::ConnectionTimeouts const&, DB::ProxyConfiguration const&) @ 0x0000000020973f1a 9. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:265: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x0000000020bae2a3 10. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x0000000020bae915 11. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x0000000020bb05f8 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x0000000020bb7761 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::doWithRetries(std::function&&, std::function, bool) const @ 0x0000000020ba933f 14. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x0000000020bb3e3c 15. DB::ReadBuffer::next() @ 0x00000000095afaaf 16. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::ReadWriteBufferFromHTTP(DB::HTTPConnectionGroupType const&, Poco::URI const&, String const&, DB::ProxyConfiguration, DB::ReadSettings, DB::ConnectionTimeouts, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*, unsigned long, unsigned long, std::function>&)>, bool, bool, std::vector>, bool, std::optional) @ 0x0000000020bad51a 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:0: std::__unique_if::__unique_single std::make_unique[abi:v15007]>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&>(DB::HTTPConnectionGroupType&, Poco::URI&, String&, DB::ProxyConfiguration&, DB::ReadSettings&, DB::ConnectionTimeouts&, Poco::Net::HTTPBasicCredentials const&, DB::RemoteHostFilter const*&, unsigned long&, unsigned long&, std::function>&)>&, bool&, bool&, std::vector>&, bool&, std::nullopt_t const&) @ 0x0000000020b9c146 18. ./src/IO/ReadWriteBufferFromHTTP.h:242: DB::StorageURLSource::getFirstAvailableURIAndReadBuffer(std::__wrap_iter&, std::__wrap_iter const&, std::shared_ptr, std::vector, std::allocator>> const&, String const&, std::function>&)>, DB::ConnectionTimeouts const&, Poco::Net::HTTPBasicCredentials&, std::vector> const&, bool, bool) @ 0x0000000038c6845e 19. ./build_docker/./src/Storages/StorageURL.cpp:799: DB::(anonymous namespace)::ReadBufferIterator::next() @ 0x0000000038c86e3d 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad6f75a 21. ./contrib/llvm-project/libcxx/include/optional:260: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad81c9e 22. ./build_docker/./src/Storages/StorageURL.cpp:0: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x0000000038c6e516 23. ./contrib/llvm-project/libcxx/include/optional:260: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c5dcaa 24. ./build_docker/./src/Storages/StorageURL.cpp:1380: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c7951c 25. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageURL* std::construct_at[abi:v15007], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca51fb 26. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca4e29 27. ./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&) @ 0x0000000038c95d14 28. ./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 @ 0x00000000382ef4c6 29. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 31. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 2025.03.31 19:12:15.355701 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:15.715930 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:15.716462 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:16.379777 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:16.516017 [ 15299 ] {b6d2426d-58c2-4999-a7cb-00c9745a6f92} executeQuery: Code: 42. DB::Exception: Storage URL requires 1-4 arguments: url, name of used format (taken from file extension by default), optional compression method, optional headers (specified as `headers('name'='value', 'name2'='value2')`). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:32964) (comment: 01030_storage_url_syntax.sql) (in query: create table test_table_url_syntax (id UInt32) ENGINE = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Storages/StorageURL.cpp:1551: DB::StorageURL::getConfiguration(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x0000000038c859e3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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&) @ 0x0000000038c956d5 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382ef4c6 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:12:16.517482 [ 15299 ] {b6d2426d-58c2-4999-a7cb-00c9745a6f92} TCPHandler: Code: 42. DB::Exception: Storage URL requires 1-4 arguments: url, name of used format (taken from file extension by default), optional compression method, optional headers (specified as `headers('name'='value', 'name2'='value2')`). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Storages/StorageURL.cpp:1551: DB::StorageURL::getConfiguration(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x0000000038c859e3 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: 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&) @ 0x0000000038c956d5 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x00000000382ef4c6 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:12:16.638176 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:16.640609 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:17.439340 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:17.571272 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:17.572222 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:18.004664 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:18.005295 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:18.538438 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:18.600012 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:18.600557 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:19.132895 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:19.135287 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:19.552656 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:19.557472 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:19.586799 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:19.867341 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:19.871117 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:20.276459 [ 19142 ] {6c282753-01d8-4555-ad82-c2d97f59a150} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48224) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:12:20.278862 [ 19142 ] {6c282753-01d8-4555-ad82-c2d97f59a150} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:12:20.622338 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:20.700341 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:20.703186 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:21.248492 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:21.251281 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:21.776548 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:21.919943 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:21.920506 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:22.457905 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:22.458429 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:22.802270 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:23.097067 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:23.099932 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:23.345898 [ 2854 ] {23083e4f-360a-4fdb-8299-7a10365bdd88} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48342) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:12:23.348188 [ 2854 ] {23083e4f-360a-4fdb-8299-7a10365bdd88} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:12:23.875756 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:24.120315 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:24.120860 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:24.512277 [ 19260 ] {69346469-0af5-4955-83ef-32a7635d541c} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 1, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.23', 2, 'UTC')). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48338) (comment: 02319_timeslots_dt64.sql) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.23', 2, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a58cd 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c58af92 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:24.513425 [ 19260 ] {69346469-0af5-4955-83ef-32a7635d541c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 1, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.23', 2, 'UTC')). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a58cd 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c58af92 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:24.530796 [ 19260 ] {86a38f52-1270-49f7-82c1-643f8aaa80d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 4, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.345', 3, 'UTC'), toDecimal64(62.3, 1), toDecimal64(12.34, 2), 'one more'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48338) (comment: 02319_timeslots_dt64.sql) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.345', 3, 'UTC'), toDecimal64(62.3, 1), toDecimal64(12.34, 2), 'one more');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a58cd 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c58af92 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:24.531915 [ 19260 ] {86a38f52-1270-49f7-82c1-643f8aaa80d7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timeSlots doesn't match: passed 4, should be 2 or 3: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.345', 3, 'UTC'), toDecimal64(62.3, 1), toDecimal64(12.34, 2), 'one more'). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a58cd 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c58af92 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:24.865253 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:24.868587 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:24.950823 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:25.494279 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:25.496961 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:25.684991 [ 19260 ] {b59d1496-1b09-40d5-8847-96baee9cdda7} executeQuery: Code: 43. DB::Exception: Illegal type String of second argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.456', 3, 'UTC'), 'wrong argument'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48338) (comment: 02319_timeslots_dt64.sql) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.456', 3, 'UTC'), 'wrong 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c58b84c 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:25.686291 [ 19260 ] {b59d1496-1b09-40d5-8847-96baee9cdda7} TCPHandler: Code: 43. DB::Exception: Illegal type String of second argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.456', 3, 'UTC'), 'wrong argument'). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c58b84c 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:26.035941 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:26.082551 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:26.086366 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:26.500115 [ 2854 ] {3eb879e4-ddae-46c8-a67d-c19a3a1e5b2c} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48402) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:12:26.502282 [ 2854 ] {3eb879e4-ddae-46c8-a67d-c19a3a1e5b2c} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:12:27.253907 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:27.348926 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:27.351885 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:27.704112 [ 19260 ] {40184be9-f4cc-41fd-992f-5be73e9d497e} executeQuery: Code: 43. DB::Exception: Illegal type String of third argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.123', 3, 'UTC'), toDecimal64(600, 0), 'wrong argument'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48338) (comment: 02319_timeslots_dt64.sql) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.123', 3, 'UTC'), toDecimal64(600, 0), 'wrong 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c58bc88 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:27.705293 [ 19260 ] {40184be9-f4cc-41fd-992f-5be73e9d497e} TCPHandler: Code: 43. DB::Exception: Illegal type String of third argument of function timeSlots. Must be Decimal64 when first argument is DateTime64.: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.123', 3, 'UTC'), toDecimal64(600, 0), 'wrong argument'). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. DB::(anonymous namespace)::FunctionTimeSlots::getReturnTypeImpl(std::vector> const&) const @ 0x000000001c58bc88 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:28.335312 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:28.511489 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:28.515145 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:29.315493 [ 19260 ] {173fc7b2-48c7-4d39-9a0c-6055eb6bf55c} executeQuery: Code: 44. DB::Exception: Third argument for function timeSlots must be greater than zero: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.1232', 4, 'UTC'), toDecimal64(600, 0), toDecimal64(0, 0)). (ILLEGAL_COLUMN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48338) (comment: 02319_timeslots_dt64.sql) (in query: SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.1232', 4, 'UTC'), toDecimal64(600, 0), toDecimal64(0, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionTimeSlots::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c587e28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:12:29.316794 [ 19260 ] {173fc7b2-48c7-4d39-9a0c-6055eb6bf55c} TCPHandler: Code: 44. DB::Exception: Third argument for function timeSlots must be greater than zero: In scope SELECT timeSlots(toDateTime64('2000-01-02 03:04:05.1232', 4, 'UTC'), toDecimal64(600, 0), toDecimal64(0, 0)). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. DB::(anonymous namespace)::FunctionTimeSlots::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c587e28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:12:29.406120 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:29.667898 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:29.668519 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:29.678131 [ 19260 ] {9ca44fd8-1ff8-4b0f-b0ff-ab31302eff5d} executeQuery: Code: 57. DB::Exception: Table test_3.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59970) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:12:29.680320 [ 19260 ] {9ca44fd8-1ff8-4b0f-b0ff-ab31302eff5d} TCPHandler: Code: 57. DB::Exception: Table test_3.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:12:30.117207 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:30.120175 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:30.451593 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:31.374335 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:31.377396 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:31.569566 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:32.034544 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:32.036892 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:32.506749 [ 3606 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {44a6cca4-034c-4831-8768-cb7a26f63c3c::202503_1_120_46}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009656d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009133f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff77dff 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x0000000020113c7f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3a3572 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a0374 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:32.653562 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:32.744498 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:32.747432 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:33.232520 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:33.235193 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:33.750582 [ 3599 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fce196b8-b32c-4319-8cdf-3d340eb025b8::202503_219_229_2}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:33.774776 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:34.223671 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:34.235772 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:34.810901 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:35.135327 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:35.136759 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039d03d22 16. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f91bf1 19. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000034f9c58b 20. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e68dd2 21. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 22. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aa57c 23. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 24. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:35.415723 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:35.416204 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:35.786937 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:35.787501 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:35.879909 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:36.734410 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:36.735007 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:36.995335 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:37.755265 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:37.758664 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:38.025589 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:38.468918 [ 4240 ] {423f01f9-441d-423d-9a63-16bdd7bda190} 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.10457.altinitytest (altinity build)) (from [::1]:60168) (comment: 00152_insert_different_granularity.sql) (in query: INSERT INTO fixed_granularity_table SELECT * FROM test.hits 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae5cf59 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:12:38.497351 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:38.500192 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:38.513880 [ 4240 ] {423f01f9-441d-423d-9a63-16bdd7bda190} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae5cf59 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:12:39.095040 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:39.099274 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:39.235846 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:39.432528 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:39.467191 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:40.032244 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:40.035902 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:40.344771 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:40.826872 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:40.832478 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:41.398255 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:41.896203 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:41.896780 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:42.459495 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:43.084789 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:43.088549 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:43.500350 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:44.383882 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:44.387849 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:44.565081 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:45.642025 [ 4240 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:45.715990 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:45.719062 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:45.811186 [ 19204 ] {ed3ce534-59b2-4d8c-82d5-d6645fe9f902} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57804) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd7ed7 5. ./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&) @ 0x0000000034d81425 6. ./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&) @ 0x0000000034d568d7 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf7a3e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 10. ./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*) @ 0x000000003589fd91 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:12:45.814410 [ 19204 ] {ed3ce534-59b2-4d8c-82d5-d6645fe9f902} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd7ed7 5. ./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&) @ 0x0000000034d81425 6. ./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&) @ 0x0000000034d568d7 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf7a3e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 10. ./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*) @ 0x000000003589fd91 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:12:46.048073 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:46.051501 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:46.236947 [ 12294 ] {a6558c95-fd71-4643-a023-6b7aed90f300} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 101.77 MiB (attempt to allocate chunk of 2253014 bytes), maximum: 100.00 MiB.: while pushing to view test_1.mv_01278_7 (b88eef05-a20f-4f23-b09c-ac80f7e10324). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60200) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 8. ./src/Common/PODArray.h:0: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000037f48479 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:140: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000037578212 10. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000003749a508 11. ./src/Columns/FilterDescription.h:40: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000037f8498d 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b7f7ae1 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b7f4d44 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba6a6db 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7e63fb 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7e5a76 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7e4c0b 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 28. ./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*) @ 0x000000003ae5cf59 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:46.282700 [ 12294 ] {a6558c95-fd71-4643-a023-6b7aed90f300} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 101.77 MiB (attempt to allocate chunk of 2253014 bytes), maximum: 100.00 MiB.: while pushing to view test_1.mv_01278_7 (b88eef05-a20f-4f23-b09c-ac80f7e10324). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 8. ./src/Common/PODArray.h:0: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000037f48479 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:140: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000037578212 10. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000003749a508 11. ./src/Columns/FilterDescription.h:40: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000037f8498d 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b7f7ae1 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b7f4d44 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba6a6db 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7e63fb 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7e5a76 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7e4c0b 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 28. ./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*) @ 0x000000003ae5cf59 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:46.602060 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:46.605331 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:46.857004 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:47.155522 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:47.159673 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:47.747302 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:47.750361 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:47.891995 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:48.665885 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:48.666486 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:48.936680 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:49.111757 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:49.114862 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:49.774221 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:49.775027 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:49.981145 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:50.607358 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:50.610900 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:50.713500 [ 15299 ] {eee46507-d6e5-4d0c-8abb-17ff6b5f1c81} executeQuery: Code: 715. DB::Exception: The data format cannot be detected by the contents of the files: Poco::Exception. Code: 1000, e.code() = 111, Connection refused (version 24.8.14.10457.altinitytest (altinity build)). You can specify the format manually. (CANNOT_DETECT_FORMAT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:32964) (comment: 01030_storage_url_syntax.sql) (in query: create table test_table_url(id UInt32) ENGINE = URL('http://localhost/endpoint') ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad80a74 5. ./contrib/llvm-project/libcxx/include/optional:260: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad81c9e 6. ./build_docker/./src/Storages/StorageURL.cpp:0: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x0000000038c6e516 7. ./contrib/llvm-project/libcxx/include/optional:260: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c5dcaa 8. ./build_docker/./src/Storages/StorageURL.cpp:1380: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c7951c 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageURL* std::construct_at[abi:v15007], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca51fb 10. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca4e29 11. ./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&) @ 0x0000000038c95d14 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:12:50.715222 [ 15299 ] {eee46507-d6e5-4d0c-8abb-17ff6b5f1c81} TCPHandler: Code: 715. DB::Exception: The data format cannot be detected by the contents of the files: Poco::Exception. Code: 1000, e.code() = 111, Connection refused (version 24.8.14.10457.altinitytest (altinity build)). You can specify the format manually. (CANNOT_DETECT_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad80a74 5. ./contrib/llvm-project/libcxx/include/optional:260: DB::detectFormatAndReadSchema(std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000003ad81c9e 6. ./build_docker/./src/Storages/StorageURL.cpp:0: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x0000000038c6e516 7. ./contrib/llvm-project/libcxx/include/optional:260: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c5dcaa 8. ./build_docker/./src/Storages/StorageURL.cpp:1380: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c7951c 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageURL* std::construct_at[abi:v15007], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca51fb 10. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca4e29 11. ./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&) @ 0x0000000038c95d14 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:12:51.062316 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:51.220149 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:51.220704 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:52.021823 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:52.024958 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:52.112140 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:52.125569 [ 4240 ] {f6d622bd-21b4-474d-9272-56d472636b65} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 100.73 MiB (attempt to allocate chunk of 1457024 bytes), maximum: 100.00 MiB.: while pushing to view test_1.mv_01278_8 (ec2cdcf7-ade1-4e84-8fcc-9a84c59ff196). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57864) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 8. ./src/Common/PODArray.h:0: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000037f48479 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:140: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000037578212 10. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000003749a508 11. ./src/Columns/FilterDescription.h:40: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000037f8498d 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b7f7ae1 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b7f4d44 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba6a6db 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7e63fb 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7e5a76 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7e4c0b 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 28. ./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*) @ 0x000000003ae5cf59 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:52.187035 [ 4240 ] {f6d622bd-21b4-474d-9272-56d472636b65} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 100.73 MiB (attempt to allocate chunk of 1457024 bytes), maximum: 100.00 MiB.: while pushing to view test_1.mv_01278_8 (ec2cdcf7-ade1-4e84-8fcc-9a84c59ff196). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000200967b0 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094a72 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 8. ./src/Common/PODArray.h:0: void DB::filterArraysImpl(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul> const&, long) @ 0x0000000037f48479 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:140: DB::ColumnString::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x0000000037578212 10. ./build_docker/./src/Columns/ColumnNullable.cpp:0: DB::ColumnNullable::filter(DB::PODArray, 63ul, 64ul> const&, long) const @ 0x000000003749a508 11. ./src/Columns/FilterDescription.h:40: DB::FilterDescription::filter(DB::IColumn const&, long) const @ 0x0000000037f8498d 12. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x000000003b7f7ae1 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::FilterTransform::transform(DB::Chunk&) @ 0x000000003b7f4d44 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 16. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 20. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000003ba6a6db 21. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003b7e63fb 22. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000003b7e5a76 23. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:0: DB::ExceptionKeepingTransform::work() @ 0x000000003b7e4c0b 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 28. ./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*) @ 0x000000003ae5cf59 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:12:52.320675 [ 15299 ] {9c5e5653-622f-483c-82b3-efdef2360e8b} executeQuery: Code: 73. DB::Exception: Unknown format ErrorFormat. (UNKNOWN_FORMAT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:32964) (comment: 01030_storage_url_syntax.sql) (in query: create table test_table_url(id UInt32) ENGINE = URL('http://localhost/endpoint', 'ErrorFormat') ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:877: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ac55637 5. ./build_docker/./src/Storages/StorageURL.cpp:0: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c5d9e8 6. ./build_docker/./src/Storages/StorageURL.cpp:1380: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c7951c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageURL* std::construct_at[abi:v15007], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca51fb 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca4e29 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&) @ 0x0000000038c95d14 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 @ 0x00000000382ef4c6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:12:52.322442 [ 15299 ] {9c5e5653-622f-483c-82b3-efdef2360e8b} TCPHandler: Code: 73. DB::Exception: Unknown format ErrorFormat. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:877: DB::FormatFactory::checkFormatName(String const&) const @ 0x000000003ac55637 5. ./build_docker/./src/Storages/StorageURL.cpp:0: DB::IStorageURLBase::IStorageURLBase(String const&, std::shared_ptr const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c5d9e8 6. ./build_docker/./src/Storages/StorageURL.cpp:1380: DB::StorageURL::StorageURL(String const&, DB::StorageID const&, String const&, std::optional const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr const&, String const&, std::vector> const&, String const&, std::shared_ptr, bool) @ 0x0000000038c7951c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::StorageURL* std::construct_at[abi:v15007], String&, std::vector>&, String&, std::shared_ptr&, DB::StorageURL*>(DB::StorageURL*, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca51fb 8. ./contrib/llvm-project/libcxx/include/__memory/allocation_guard.h:66: std::shared_ptr std::allocate_shared[abi:v15007], String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr, String&, std::vector>&, String&, std::shared_ptr&, void>(std::allocator const&, String&, DB::StorageID const&, String&, DB::FormatSettings&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, std::shared_ptr&&, String&, std::vector>&, String&, std::shared_ptr&) @ 0x0000000038ca4e29 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&) @ 0x0000000038c95d14 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 @ 0x00000000382ef4c6 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:12:52.350237 [ 15299 ] {22db9f91-9fdf-4c7b-b58d-38babf96ef68} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage URL. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:32964) (comment: 01030_storage_url_syntax.sql) (in query: drop table test_table_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:12:52.351256 [ 15299 ] {22db9f91-9fdf-4c7b-b58d-38babf96ef68} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage URL. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:12:53.018507 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:53.022364 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:53.187639 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:53.548169 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:53.548775 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:53.867695 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=728). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:54.091686 [ 19204 ] {9b51eba1-3bde-4a2f-b6ed-27d8eb3b1b22} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=728). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55454) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (in query: insert into data_01278 select number, reinterpretAsString(number), // s1 reinterpretAsString(number), // s2 reinterpretAsString(number), // s3 reinterpretAsString(number), // s4 reinterpretAsString(number), // s5 reinterpretAsString(number), // s6 reinterpretAsString(number), // s7 reinterpretAsString(number) // s8 from numbers(200000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5b764 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003ab951ce 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:12:54.101673 [ 19203 ] {b5c0ff8b-1737-4c4f-9bae-def6762e151d} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55502) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000034e64a6d 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000034e6765a 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6582c 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6644d 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*) @ 0x00000000358988ad 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:12:54.102213 [ 19204 ] {9b51eba1-3bde-4a2f-b6ed-27d8eb3b1b22} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=728). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::CompletedPipelineExecutor::execute() @ 0x000000003ae5b764 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000003ab951ce 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:12:54.103824 [ 19203 ] {b5c0ff8b-1737-4c4f-9bae-def6762e151d} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x0000000034e64a6d 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x0000000034e6765a 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6582c 11. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:72: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000034e6644d 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*) @ 0x00000000358988ad 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 15. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:12:54.238964 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:54.337765 [ 12294 ] {e1d16e03-efe0-4ac6-af11-3fa6cb6f05e5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56660) (comment: 00321_pk_set.sql) (in query: DROP DATABASE IF EXISTS test_cbawq5wc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:12:54.339986 [ 12294 ] {e1d16e03-efe0-4ac6-af11-3fa6cb6f05e5} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:54.354841 [ 19204 ] {e448ad31-9c9c-4fa3-ab58-2c2c8c20b9cd} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56664) (comment: 00321_pk_set.sql) (in query: DROP DATABASE IF EXISTS test_cbawq5wc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:12:54.356913 [ 19204 ] {e448ad31-9c9c-4fa3-ab58-2c2c8c20b9cd} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:54.371751 [ 19200 ] {81a61b50-9f4f-450b-bee2-f5d2da88c0d7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56676) (comment: 00321_pk_set.sql) (in query: DROP DATABASE IF EXISTS test_cbawq5wc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:12:54.374117 [ 19200 ] {81a61b50-9f4f-450b-bee2-f5d2da88c0d7} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:54.389944 [ 19204 ] {d94ad9a1-7533-4ad1-9e59-2bb86f0f0cb5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56690) (comment: 00321_pk_set.sql) (in query: DROP DATABASE IF EXISTS test_cbawq5wc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:12:54.391877 [ 19204 ] {d94ad9a1-7533-4ad1-9e59-2bb86f0f0cb5} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:54.406511 [ 19203 ] {a23d128b-5992-46cd-bfdc-9a7f05ee77b6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:56698) (comment: 00321_pk_set.sql) (in query: DROP DATABASE IF EXISTS test_cbawq5wc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:12:54.408472 [ 19203 ] {a23d128b-5992-46cd-bfdc-9a7f05ee77b6} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:54.696824 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=728). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 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) @ 0x0000000034f6039a 9. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000039e65536 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 11. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aa57c 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:55.056036 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:55.059972 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:55.301944 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:55.889979 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:55.890588 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:56.336658 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:56.819728 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:56.822960 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:57.378997 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:57.929357 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:57.932673 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:58.489897 [ 19204 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:58.855999 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:58.858837 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:59.562564 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:12:59.726033 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:12:59.728847 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:00.143519 [ 12293 ] {68d5f0db-f987-44ef-868e-07ae7f5f727d} 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.10457.altinitytest (altinity build)) (from [::1]:48172) (comment: 01517_select_final_distributed.sql) (in query: SELECT `__table1`.`Id` AS `Id`, `__table1`.`Timestamp` AS `Timestamp` FROM `test_0zyyn8yq`.`test5346` AS `__table1` FINAL ORDER BY identity(`__table1`.`Timestamp`) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ce71b2 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&) @ 0x0000000039ce966a 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 @ 0x0000000032630982 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263138d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce0b44 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) @ 0x0000000039ce0469 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&) @ 0x000000003999ab28 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 @ 0x000000003998fbb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c03fa33 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf9e973 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:13:00.146555 [ 12293 ] {68d5f0db-f987-44ef-868e-07ae7f5f727d} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ce71b2 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&) @ 0x0000000039ce966a 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 @ 0x0000000032630982 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263138d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce0b44 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) @ 0x0000000039ce0469 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&) @ 0x000000003999ab28 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 @ 0x000000003998fbb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c03fa33 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf9e973 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:13:00.152578 [ 19204 ] {0da84b55-7489-4a84-a6ec-5d2b84d269ab} executeQuery: Code: 439. DB::Exception: Received from localhost:9000. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ce71b2 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&) @ 0x0000000039ce966a 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 @ 0x0000000032630982 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263138d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce0b44 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) @ 0x0000000039ce0469 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&) @ 0x000000003999ab28 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 @ 0x000000003998fbb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c03fa33 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf9e973 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:55618) (comment: 01517_select_final_distributed.sql) (in query: SELECT Id, Timestamp FROM remote('localhost,127.0.0.1,127.0.0.2',currentDatabase(),'test5346') FINAL ORDER BY identity(Timestamp);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8bfc78 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:13:00.156886 [ 19200 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:59898, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x00000000204ba910 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x00000000204bb8a1 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7e374d 6. DB::ReadBuffer::next() @ 0x00000000095afaaf 7. ./src/IO/ReadBuffer.h:106: DB::TCPHandler::runImpl() @ 0x000000003ab92e9e 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:00.157873 [ 19204 ] {0da84b55-7489-4a84-a6ec-5d2b84d269ab} TCPHandler: Code: 439. DB::Exception: Received from localhost:9000. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ce71b2 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&) @ 0x0000000039ce966a 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 @ 0x0000000032630982 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263138d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce0b44 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) @ 0x0000000039ce0469 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&) @ 0x000000003999ab28 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 @ 0x000000003998fbb4 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25050 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c03fa33 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf9e973 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 23. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 24. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 29. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 31. ? @ 0x00007f038ce47ac3 : 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8bfc78 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:13:00.251357 [ 19203 ] {a5793f97-d7b2-4df1-a268-410925f973c4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39836) (comment: 01517_select_final_distributed.sql) (in query: DROP DATABASE IF EXISTS test_0zyyn8yq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:00.253396 [ 19203 ] {a5793f97-d7b2-4df1-a268-410925f973c4} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:00.269325 [ 19200 ] {1d5f83a1-59d5-4335-b366-5a9d3bed5398} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39846) (comment: 01517_select_final_distributed.sql) (in query: DROP DATABASE IF EXISTS test_0zyyn8yq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:00.271533 [ 19200 ] {1d5f83a1-59d5-4335-b366-5a9d3bed5398} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:00.286410 [ 3830 ] {767ffa29-3653-46d2-b06b-0fbbc2649365} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39854) (comment: 01517_select_final_distributed.sql) (in query: DROP DATABASE IF EXISTS test_0zyyn8yq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:00.288533 [ 3830 ] {767ffa29-3653-46d2-b06b-0fbbc2649365} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:00.304396 [ 19200 ] {f36cd97b-a03d-4c1e-b162-83598fda5878} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39862) (comment: 01517_select_final_distributed.sql) (in query: DROP DATABASE IF EXISTS test_0zyyn8yq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:00.306871 [ 19200 ] {f36cd97b-a03d-4c1e-b162-83598fda5878} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:00.397842 [ 3830 ] {b1792a0a-dcc2-463a-a445-d23cb24bc79b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39870) (comment: 01517_select_final_distributed.sql) (in query: DROP DATABASE IF EXISTS test_0zyyn8yq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:00.400017 [ 3830 ] {b1792a0a-dcc2-463a-a445-d23cb24bc79b} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:00.625414 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:00.772762 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:00.773349 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:01.655726 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:01.814442 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:01.818688 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:02.604022 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:02.607461 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:02.660879 [ 19204 ] {72935b56-02cf-4a95-85e9-72a998977f57} executeQuery: Code: 62. DB::Exception: Syntax error (columns declaration list): failed at position 3 (end of query): . Expected one of: NULL, NOT, DEFAULT, MATERIALIZED, EPHEMERAL, ALIAS, AUTO_INCREMENT, PRIMARY KEY, data type, identifier. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48196) (comment: 01256_negative_generate_random.sql) (in query: SELECT * FROM generateRandom('i8', 1, 10, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840353e 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) @ 0x000000003d179aca 4. ./build_docker/./src/Parsers/parseQuery.cpp:432: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d179d67 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:162: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003599a1d3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe61cd2 7. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:0: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe6279e 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f03b3 9. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003373d2f2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000334503f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334de021 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:13:02.662583 [ 19204 ] {72935b56-02cf-4a95-85e9-72a998977f57} TCPHandler: Code: 62. DB::Exception: Syntax error (columns declaration list): failed at position 3 (end of query): . Expected one of: NULL, NOT, DEFAULT, MATERIALIZED, EPHEMERAL, ALIAS, AUTO_INCREMENT, PRIMARY KEY, data type, identifier. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840353e 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) @ 0x000000003d179aca 4. ./build_docker/./src/Parsers/parseQuery.cpp:432: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d179d67 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:162: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003599a1d3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe61cd2 7. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:0: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe6279e 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f03b3 9. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003373d2f2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000334503f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334de021 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:13:02.764625 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:03.330339 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:03.334059 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:03.640971 [ 19204 ] {8d327c26-b235-44e2-8f64-7d553e0c7bde} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'generateRandom' in scope SELECT * FROM generateRandom. (UNKNOWN_TABLE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48196) (comment: 01256_negative_generate_random.sql) (in query: SELECT * FROM generateRandom;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa04d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334db18a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033426e8d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:13:03.642233 [ 19204 ] {8d327c26-b235-44e2-8f64-7d553e0c7bde} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'generateRandom' in scope SELECT * FROM generateRandom. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000aa04d8d 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334db18a 5. ./contrib/llvm-project/libcxx/include/__hash_table:932: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033426e8d 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:13:03.664276 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:03.664818 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:03.843521 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:03.958815 [ 19200 ] {ce06a5e5-4bed-48e9-bd08-2f13e4055bcc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48238) (comment: 00156_max_execution_speed_sample_merge.sql) (in query: SELECT count() FROM merge(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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:13:03.962198 [ 19200 ] {ce06a5e5-4bed-48e9-bd08-2f13e4055bcc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=729). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:13:04.624164 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:04.647779 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:04.883208 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:05.183431 [ 19204 ] {0bc181a2-0727-47e6-a2b9-4ab5ca5caed9} executeQuery: Code: 42. DB::Exception: Table function 'generateRandom' requires at most four (or three if structure is missing) arguments: [structure, random_seed, max_string_length, max_array_length]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48196) (comment: 01256_negative_generate_random.sql) (in query: SELECT * FROM generateRandom('i8 UInt8', 1, 10, 10, 10, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:79: DB::(anonymous namespace)::TableFunctionGenerateRandom::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fe61180 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003344d62b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334de021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:13:05.184727 [ 19204 ] {0bc181a2-0727-47e6-a2b9-4ab5ca5caed9} TCPHandler: Code: 42. DB::Exception: Table function 'generateRandom' requires at most four (or three if structure is missing) arguments: [structure, random_seed, max_string_length, max_array_length]. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:79: DB::(anonymous namespace)::TableFunctionGenerateRandom::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x000000002fe61180 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000003344d62b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334de021 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427080 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:13:05.281010 [ 19204 ] {5b66490c-dac7-4f4a-b115-091bef2abbe2} executeQuery: Code: 62. DB::Exception: Empty query. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48196) (comment: 01256_negative_generate_random.sql) (in query: SELECT * FROM generateRandom('', 1, 10, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840353e 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) @ 0x000000003d179aca 4. ./build_docker/./src/Parsers/parseQuery.cpp:432: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d179d67 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:162: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003599a1d3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe61cd2 7. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:0: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe6279e 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f03b3 9. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003373d2f2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000334503f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334de021 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:13:05.282297 [ 19204 ] {5b66490c-dac7-4f4a-b115-091bef2abbe2} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000840353e 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) @ 0x000000003d179aca 4. ./build_docker/./src/Parsers/parseQuery.cpp:432: DB::parseQuery(DB::IParser&, String const&, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000003d179d67 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:162: DB::parseColumnsListFromString(String const&, std::shared_ptr const&) @ 0x000000003599a1d3 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::(anonymous namespace)::TableFunctionGenerateRandom::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002fe61cd2 7. ./build_docker/./src/TableFunctions/TableFunctionGenerateRandom.cpp:0: DB::(anonymous namespace)::TableFunctionGenerateRandom::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000002fe6279e 8. ./build_docker/./src/TableFunctions/ITableFunction.cpp:0: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000306f03b3 9. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003373d2f2 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4819: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x00000000334503f1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000334de021 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427080 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:13:05.597459 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:05.600723 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:05.730278 [ 3830 ] {d9339b26-c0ac-4282-9bcb-125a937f0e3c} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48280) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (in query: drop table if exists part_01278_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:13:05.732743 [ 3830 ] {d9339b26-c0ac-4282-9bcb-125a937f0e3c} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:13:05.967883 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:06.456959 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:06.479437 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:06.876688 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:06.877288 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:07.000992 [ 3830 ] {86f7d712-c16f-4bfc-a05d-2a190763bef2} executeQuery: Code: 57. DB::Exception: Table test_3.ordinary_distinct already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48308) (comment: 00174_distinct_in_order.sql) (in query: CREATE TABLE ordinary_distinct (`CounterID` UInt32, `EventDate` Date) ENGINE = MergeTree ORDER BY (CounterID, EventDate) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 643333900, ratio_of_defaults_for_sparse_serialization = 0.15314193069934845, replace_long_file_name_to_hash = false, max_file_name_length = 33, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 187042116, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 27508333, merge_max_block_size = 4823, old_parts_lifetime = 276., 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 = 5479157322, concurrent_part_removal_threshold = 99, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 16869, primary_key_compress_block_size = 80094), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:13:07.003488 [ 3830 ] {86f7d712-c16f-4bfc-a05d-2a190763bef2} TCPHandler: Code: 57. DB::Exception: Table test_3.ordinary_distinct 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:13:07.023973 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:07.157441 [ 19288 ] {102fc0b0-c57f-430e-b74d-5b33e3065353} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48326) (comment: 01278_min_insert_block_size_rows_for_materialized_views.sh) (in query: drop table if exists out_01278;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:13:07.159364 [ 19288 ] {102fc0b0-c57f-430e-b74d-5b33e3065353} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:13:07.724154 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:07.728138 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:08.170260 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:08.173063 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:08.329888 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:09.143274 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:09.143853 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:09.384098 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:09.414219 [ 3599 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c38c8cc9-27b1-4991-900a-4bc8e9c3b6da::202503_1_119_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:09.867485 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:09.870752 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:10.571883 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:10.712678 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:10.713341 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:11.498656 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:11.501241 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:11.666583 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:12.386171 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:12.390081 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:12.695899 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:12.907767 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:12.910969 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:13.741238 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:13.832127 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:13.832767 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:14.274223 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:14.277821 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:14.831927 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:15.114305 [ 19260 ] {68f25d99-1f9c-49f5-ad8b-ff2926389444} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(-1, 0). (ILLEGAL_DIVISION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45440) (comment: 00977_int_div.sql) (in query: SELECT -1 DIV 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. _ZN2DB25throwIfDivisionLeadsToFPEIDB8_S1_EEvT_T0_ @ 0x000000000fe4836e 5. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001368cdbf 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000013685dc3 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001355a51d 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001354acd6 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000135457cb 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013541f9c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:13:15.115462 [ 19260 ] {68f25d99-1f9c-49f5-ad8b-ff2926389444} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(-1, 0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. _ZN2DB25throwIfDivisionLeadsToFPEIDB8_S1_EEvT_T0_ @ 0x000000000fe4836e 5. COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001368cdbf 6. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x0000000013685dc3 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000001355a51d 8. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000001354acd6 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000135457cb 10. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000013541f9c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:13:15.528240 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:15.531565 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:15.868642 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:16.021244 [ 19288 ] {f6c3dea6-378d-4fb3-a87a-582a4780d7b3} executeQuery: Code: 57. DB::Exception: Table test_6fpvhrae.ttl_00933_1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:45430) (comment: 00933_ttl_simple.sql) (in query: create table ttl_00933_1 (d Date, a Int) engine = MergeTree order by a partition by toDayOfMonth(d) ttl d + interval 1 day settings remove_empty_parts = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:13:16.022725 [ 19288 ] {f6c3dea6-378d-4fb3-a87a-582a4780d7b3} TCPHandler: Code: 57. DB::Exception: Table test_6fpvhrae.ttl_00933_1 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:13:16.050766 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:16.054409 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:16.117629 [ 12293 ] {aeb8b3f6-3cb8-4b70-9ce8-7b1d78ba5bfc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:34680) (comment: 00933_ttl_simple.sql) (in query: DROP DATABASE IF EXISTS test_6fpvhrae ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:16.120050 [ 12293 ] {aeb8b3f6-3cb8-4b70-9ce8-7b1d78ba5bfc} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:16.926174 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:17.104267 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:17.107923 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:17.360585 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:17.364012 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:17.994952 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:18.450561 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:18.454216 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:19.239301 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:19.321527 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:19.324365 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:20.144189 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:20.144726 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:20.271681 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:21.179803 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:21.183125 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:21.307653 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:13:21.986476 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:21.990228 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:22.862585 [ 19288 ] {140fc753-0260-4f3b-9ba6-4675dc23fdd9} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59174) (comment: 02154_dictionary_get_http_json.sh) (in query: DROP DICTIONARY 02154_test_dictionary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:13:22.864803 [ 19288 ] {140fc753-0260-4f3b-9ba6-4675dc23fdd9} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:13:23.324078 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:23.326997 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:23.492498 [ 2854 ] {1e0e88c8-767d-4244-a228-b3dff9417832} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test_p8jd6ior.`02154_test_source_table` (5396aac8-53a0-40cc-8561-eae044b9e6c9), because some tables depend on it: test_p8jd6ior.`02154_test_dictionary`. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59200) (comment: 02154_dictionary_get_http_json.sh) (in query: DROP TABLE 02154_test_source_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c41f9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034929042 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:23.494667 [ 2854 ] {1e0e88c8-767d-4244-a228-b3dff9417832} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test_p8jd6ior.`02154_test_source_table` (5396aac8-53a0-40cc-8561-eae044b9e6c9), because some tables depend on it: test_p8jd6ior.`02154_test_dictionary`. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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>&&) @ 0x00000000339dd68d 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c2adf 5. ./contrib/llvm-project/libcxx/include/__mutex_base:100: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamed(DB::StorageID const&, bool, bool, bool) const @ 0x00000000339c41f9 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034929042 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:23.676937 [ 19288 ] {485b15ca-3fab-4d4f-9057-cd19b7059e51} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57742) (comment: 02154_dictionary_get_http_json.sh) (in query: DROP DATABASE IF EXISTS test_p8jd6ior ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:23.679336 [ 19288 ] {485b15ca-3fab-4d4f-9057-cd19b7059e51} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:23.780887 [ 19199 ] {17bc0d76-2db0-43a1-9c8b-07dc968813e5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57744) (comment: 02154_dictionary_get_http_json.sh) (in query: DROP DATABASE IF EXISTS test_p8jd6ior ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:23.783076 [ 19199 ] {17bc0d76-2db0-43a1-9c8b-07dc968813e5} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:24.040528 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:24.043605 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:24.392092 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:24.396085 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:25.100466 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:25.103981 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:25.356747 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:25.361491 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:25.748629 [ 3597 ] {311be05f-6e5e-4acc-9d75-8caeaa065d15::all_0_0_1} 311be05f-6e5e-4acc-9d75-8caeaa065d15::all_0_0_1 (MergeFromLogEntryTask): Code: 40. DB::Exception: Checksums of parts don't match: uncompressed hash of compressed files doesn't match (e8e6cd8c44ee8997846ca164452493f9 vs faff69f890e9c4124c35accc430fbc05). (CHECKSUM_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 1 (db7b13ffcb46ab2bbdf9b8450495b777) data.bin: 209 (7e373025bd29bdaf4400b09b279f7817) data.cmrk3: 66 (89616030e5036d8a6a9baa2d4c70b7f3) primary.cidx: 42 (10356a73f3f7cd67e05a9b5220efb901) serialization.json: 289 (ab34c931870056bb20b246c485878d77) 2025.03.31 19:13:25.951876 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:25.955279 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:26.579917 [ 2854 ] {34b66293-dfdc-49e1-a57d-695ec0f04cc9} 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.10457.altinitytest (altinity build)) (from [::1]:59226) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008459d8a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491a9f4 5. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038093fd4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348541d1 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:13:26.581377 [ 2854 ] {34b66293-dfdc-49e1-a57d-695ec0f04cc9} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x0000000008459d8a 4. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:0: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003491a9f4 5. ./build_docker/./src/Storages/AlterCommands.cpp:0: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000038093fd4 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000348541d1 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:13:26.670152 [ 19288 ] {e705ab6b-5fb5-4a0d-abc4-1346f1abf9b3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57790) (comment: 01455_default_compression.sql) (in query: DROP DATABASE IF EXISTS test_444yhd00 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:26.672066 [ 19288 ] {e705ab6b-5fb5-4a0d-abc4-1346f1abf9b3} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:26.752385 [ 2854 ] {ca5dac73-695e-4902-96b2-8ddb49ab9a54} 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.10457.altinitytest (altinity build)) (from [::1]:57804) (comment: 01455_default_compression.sql) (in query: DROP DATABASE IF EXISTS test_444yhd00 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:13:26.754793 [ 2854 ] {ca5dac73-695e-4902-96b2-8ddb49ab9a54} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:26.812434 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:26.816078 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:27.823891 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:27.827339 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:28.202066 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:28.202685 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:28.540084 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:28.543140 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:29.083878 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:29.084487 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:29.273139 [ 19260 ] {323e86dc-aca7-472e-b179-58a166c7dad2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): (while reading from part /var/lib/clickhouse/store/311/311be05f-6e5e-4acc-9d75-8caeaa065d15/all_0_0_1/ in table test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15) located on disk default of type local, from mark 0 with max_rows_to_read = 3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59222) (comment: 00721_force_by_identical_result_after_merge_zookeeper_long.sql) (in query: SELECT x, t1.y - t2.y FROM byte_identical_r1 t1 SEMI LEFT JOIN byte_identical_r2 t2 USING x ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003074f71a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003074ef60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003074b4d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x0000000030729b4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003072ac6f 11. DB::ReadBuffer::next() @ 0x00000000095afaaf 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320d5913 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320db897 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320dbe2d 15. DB::ReadBuffer::next() @ 0x00000000095afaaf 16. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000039bedea8 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:216: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000039be9c6d 18. ./src/Common/threadPoolCallbackRunner.h:0: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000039bf2424 19. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000039bfa1e2 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039bf272e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 26. ? @ 0x00007f038ce47ac3 27. ? @ 0x00007f038ced9850 2025.03.31 19:13:29.277393 [ 19260 ] {323e86dc-aca7-472e-b179-58a166c7dad2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0): (while reading from part /var/lib/clickhouse/store/311/311be05f-6e5e-4acc-9d75-8caeaa065d15/all_0_0_1/ in table test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15) located on disk default of type local, from mark 0 with max_rows_to_read = 3): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003074f71a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003074ef60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003074b4d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x0000000030729b4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003072ac6f 11. DB::ReadBuffer::next() @ 0x00000000095afaaf 12. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:163: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x00000000320d5913 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320db897 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000320dbe2d 15. DB::ReadBuffer::next() @ 0x00000000095afaaf 16. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:168: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x0000000039bedea8 17. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:216: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x0000000039be9c6d 18. ./src/Common/threadPoolCallbackRunner.h:0: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000039bf2424 19. ./contrib/llvm-project/libcxx/include/future:1953: std::packaged_task ()>::operator()() @ 0x0000000039bfa1e2 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039bf272e 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 26. ? @ 0x00007f038ce47ac3 27. ? @ 0x00007f038ced9850 2025.03.31 19:13:30.272260 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:30.275565 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:31.230762 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:31.234503 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:31.285326 [ 3371 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:31.546557 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:31.549326 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:32.286072 [ 3301 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:32.466522 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:32.469305 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:33.084064 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:33.086981 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:33.286676 [ 3285 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:34.157112 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:34.159799 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:34.287344 [ 3256 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:34.954112 [ 15299 ] {6254f526-1e97-4cc9-85c3-d3175c68e82b} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39032) (comment: 00063_loyalty_joins.sql) (in query: SELECT loyalty, count() FROM test.hits ANY LEFT JOIN ( SELECT UserID, sum(SearchEngineID = 2) AS yandex, sum(SearchEngineID = 3) AS google, toInt8(if(yandex > google, yandex / (yandex + google), -google / (yandex + google)) * 10) AS loyalty FROM test.hits WHERE (SearchEngineID = 2) OR (SearchEngineID = 3) GROUP BY UserID HAVING (yandex + google) > 10 ) USING UserID GROUP BY loyalty ORDER BY loyalty ASC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd7ed7 5. ./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&) @ 0x0000000034d81425 6. ./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&) @ 0x0000000034d568d7 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf7a3e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 10. ./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*) @ 0x000000003589fd91 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:34.956610 [ 15299 ] {6254f526-1e97-4cc9-85c3-d3175c68e82b} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x0000000034dd7ed7 5. ./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&) @ 0x0000000034d81425 6. ./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&) @ 0x0000000034d568d7 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cf7a3e 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 10. ./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*) @ 0x000000003589fd91 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:35.287992 [ 3239 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:35.487258 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:35.491057 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:36.288674 [ 3212 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:36.764832 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:36.767844 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:37.289198 [ 3509 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:37.314260 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:37.314756 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:38.163384 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:38.163960 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:38.290029 [ 3188 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:39.290685 [ 3153 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:39.441993 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:39.445228 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:40.220175 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:40.220744 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:40.291262 [ 3130 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:41.288708 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:41.291623 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:41.291875 [ 3101 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:41.573681 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:41.574478 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:42.292580 [ 3078 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:42.739949 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:42.742898 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:43.293197 [ 3058 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:43.834881 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:43.835649 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:44.293879 [ 3030 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:44.959135 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:44.962650 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:45.295213 [ 3497 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:45.371624 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:45.374586 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:46.241117 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:46.244676 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:46.295918 [ 3459 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:47.296565 [ 3443 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:47.507158 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:47.510776 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:48.297148 [ 3423 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:48.441180 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:48.444943 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:48.863862 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:48.866709 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:49.057649 [ 4187 ] {8d2a8f7b-cba0-4f34-8871-089a265bb98e} executeQuery: Code: 57. DB::Exception: Table test.hits_tinylog already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58854) (comment: 00077_log_tinylog_stripelog.sql) (in query: CREATE TABLE test.hits_tinylog (CounterID UInt32, AdvEngineID UInt8, RegionID UInt32, SearchPhrase String, UserID UInt64) ENGINE = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:13:49.059845 [ 4187 ] {8d2a8f7b-cba0-4f34-8871-089a265bb98e} TCPHandler: Code: 57. DB::Exception: Table test.hits_tinylog 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:13:49.297961 [ 3388 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:49.653756 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:49.654270 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:50.142900 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:50.146576 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:50.298603 [ 3365 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:51.156990 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:51.160653 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:51.299445 [ 3340 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:51.768405 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:51.768860 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:52.294446 [ 3830 ] {23305286-1fbe-4552-b013-bc16e5571d7f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:53252) (comment: 01583_parallel_parsing_exception_with_offset.sh) (in query: DROP DATABASE IF EXISTS test_39tg9lp5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:52.296522 [ 3830 ] {23305286-1fbe-4552-b013-bc16e5571d7f} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:52.300087 [ 3322 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:52.651206 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:52.651872 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:52.916494 [ 12294 ] {fc387b41-397b-4579-81b4-a560aa7b5cbb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=734). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46006) (comment: 00864_union_all_supertype.sql) (in query: select toTypeName(key), toTypeName(value) from ( select toDecimal64(2, 8) as key, toNullable('') as value union all select toDecimal32(2, 4) as key, toFixedString('', 1) as 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:13:52.919493 [ 12294 ] {fc387b41-397b-4579-81b4-a560aa7b5cbb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:13:53.300740 [ 3285 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:53.550028 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:53.552819 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:53.714775 [ 3830 ] {0522a8db-99a1-4a70-b6f8-02fe3d7b3490} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:53280) (comment: 02830_insert_values_time_interval.sql) (in query: DROP DATABASE IF EXISTS test_79c9du0m ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:53.716775 [ 3830 ] {0522a8db-99a1-4a70-b6f8-02fe3d7b3490} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:53.876531 [ 19142 ] {c6f18dae-2c2a-4bd2-9753-aebf2c48e437} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:53284) (comment: 02830_insert_values_time_interval.sql) (in query: DROP DATABASE IF EXISTS test_79c9du0m ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:13:53.878597 [ 19142 ] {c6f18dae-2c2a-4bd2-9753-aebf2c48e437} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:54.301578 [ 3251 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:54.416847 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:54.453234 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:54.935976 [ 19203 ] {b0a1eee2-f615-4dda-91ab-d0f2254f77c6} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46030) (comment: 00458_merge_type_cast.sql) (in query: DROP TABLE merge_32_64;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:13:54.938000 [ 19203 ] {b0a1eee2-f615-4dda-91ab-d0f2254f77c6} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x000000002ffc1367 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034928ab5 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:13:55.302254 [ 3232 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:55.317694 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:55.318308 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:55.959683 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:55.962873 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:56.302888 [ 3199 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:56.951954 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:56.955756 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:57.303493 [ 3166 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:57.920995 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:57.923624 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:58.304153 [ 3141 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:58.887792 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:58.893360 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:59.304771 [ 3118 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:59.323950 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:13:59.327445 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:00.305433 [ 3102 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:00.385404 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:00.386113 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:00.959502 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:00.963003 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:01.202099 [ 19203 ] {16c0656c-8827-44be-9258-96b86a616869} executeQuery: Code: 6. DB::Exception: Cannot parse force_data_skipping_indices (''). (CANNOT_PARSE_TEXT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37728) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 SETTINGS force_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:595: 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) @ 0x0000000039a4245e 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:01.203392 [ 19203 ] {16c0656c-8827-44be-9258-96b86a616869} TCPHandler: Code: 6. DB::Exception: Cannot parse force_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:595: 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) @ 0x0000000039a4245e 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:01.306030 [ 3061 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:01.574449 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:01.577448 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:02.064990 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:02.068610 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:02.306605 [ 3040 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:02.411856 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:02.415031 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:02.747867 [ 19203 ] {fa8c0330-351d-4f94-9bc9-9d84a46d6e9b} executeQuery: Code: 277. DB::Exception: Index `d1_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37728) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 SETTINGS force_data_skipping_indices='d1_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:02.749254 [ 19203 ] {fa8c0330-351d-4f94-9bc9-9d84a46d6e9b} TCPHandler: Code: 277. DB::Exception: Index `d1_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:02.776766 [ 19203 ] {312a124c-db73-482b-8453-695a093ed490} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37728) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 SETTINGS force_data_skipping_indices='d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:02.781175 [ 19203 ] {312a124c-db73-482b-8453-695a093ed490} TCPHandler: Code: 277. DB::Exception: Index `d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.071772 [ 19203 ] {9b986129-90ca-400b-8ec5-2df8975d43b5} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37728) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_idx,d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.073155 [ 19203 ] {9b986129-90ca-400b-8ec5-2df8975d43b5} TCPHandler: Code: 277. DB::Exception: Index `d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.102648 [ 19203 ] {607d8319-55d8-4ff2-8d26-d6b70cb2158c} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37728) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_idx,d1_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.103813 [ 19203 ] {607d8319-55d8-4ff2-8d26-d6b70cb2158c} TCPHandler: Code: 277. DB::Exception: Index `d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.171671 [ 19203 ] {c416124f-dc5e-4045-8fa0-126c1e117f3d} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37728) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_idx,d1_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.172967 [ 19203 ] {c416124f-dc5e-4045-8fa0-126c1e117f3d} TCPHandler: Code: 277. DB::Exception: Index `d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.269859 [ 19203 ] {66a96d26-a86b-4cfe-815d-b86b736bb2c5} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37728) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' d1_null_idx,d1_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.271221 [ 19203 ] {66a96d26-a86b-4cfe-815d-b86b736bb2c5} TCPHandler: Code: 277. DB::Exception: Index `d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.307169 [ 3018 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:03.307974 [ 19203 ] {936857a9-69f2-428b-b338-af0659d0e279} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37728) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' `d1_null_idx`,d1_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.309185 [ 19203 ] {936857a9-69f2-428b-b338-af0659d0e279} TCPHandler: Code: 277. DB::Exception: Index `d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.406956 [ 19203 ] {dfd4b5a9-bb13-48a3-a790-be0e428b5d8f} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37728) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices='d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.408225 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:03.408315 [ 19203 ] {dfd4b5a9-bb13-48a3-a790-be0e428b5d8f} TCPHandler: Code: 277. DB::Exception: Index `d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.408729 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:03.439164 [ 19203 ] {82da2b30-ba7e-4efe-a3f4-2d91eec71fde} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37728) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1 = 0 SETTINGS force_data_skipping_indices=' d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.440410 [ 19203 ] {82da2b30-ba7e-4efe-a3f4-2d91eec71fde} TCPHandler: Code: 277. DB::Exception: Index `d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.552986 [ 19203 ] {3a7fed52-b876-4443-85e0-ca9356bfefa6} executeQuery: Code: 277. DB::Exception: Index `d1_null_idx` is not used and setting 'force_data_skipping_indices' contains it. (INDEX_NOT_USED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37728) (comment: 01515_force_data_skipping_indices.sql) (in query: SELECT * FROM data_01515 WHERE d1_null = 0 SETTINGS force_data_skipping_indices='d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.554731 [ 19203 ] {3a7fed52-b876-4443-85e0-ca9356bfefa6} TCPHandler: Code: 277. DB::Exception: Index `d1_null_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 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) @ 0x0000000039a422c2 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) @ 0x000000003bee63e9 6. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 10. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 17. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 21. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 22. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 23. ? @ 0x00007f038ce47ac3 24. ? @ 0x00007f038ced9850 2025.03.31 19:14:03.962444 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:03.966361 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:04.307816 [ 3488 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:05.023390 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:05.026832 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:05.308374 [ 3467 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:06.031946 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:06.032435 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:06.308898 [ 3464 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:06.489105 [ 12293 ] {caa2b0ce-b38e-4511-9371-a3e1e0aa4a9f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37824) (comment: 00181_aggregate_functions_statistics.sql) (in query: SELECT round(abs(res1 - res2), 6) FROM ( SELECT varPop(x_value) AS res1, (sum(x_value * x_value) - ((sum(x_value) * sum(x_value)) / count())) / count() AS res2 FROM series );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:06.492315 [ 12293 ] {caa2b0ce-b38e-4511-9371-a3e1e0aa4a9f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:06.566392 [ 19199 ] {a0e8e78f-7379-4fde-9fa8-56195e7b418d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35500) (comment: 00182_simple_squashing_transform_bug.sql) (in query: SELECT sum(`__table2`.`UserID` GLOBAL IN (`_data_10951897634536988111_737910315569362019` AS `__table1`)) AS `sum(globalIn(UserID, _subquery_1))` FROM `test`.`hits` AS `__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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:06.569806 [ 19199 ] {a0e8e78f-7379-4fde-9fa8-56195e7b418d} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:06.573375 [ 3830 ] {2d19a238-d041-4705-9bd8-c1baa77830db} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37832) (comment: 00182_simple_squashing_transform_bug.sql) (in query: SELECT sum(UserID GLOBAL IN (SELECT UserID FROM test.hits)) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8bfc78 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:14:06.604075 [ 19142 ] {c41be92f-fffb-4585-be62-89132acd5e93} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44856) (comment: 00181_aggregate_functions_statistics.sql) (in query: DROP DATABASE IF EXISTS test_5xprp0x5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:14:06.606434 [ 19142 ] {c41be92f-fffb-4585-be62-89132acd5e93} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:06.642617 [ 3830 ] {2d19a238-d041-4705-9bd8-c1baa77830db} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 : 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x0000000020195b12 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000003a7b628c 4. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::Connection::receivePacket() @ 0x000000003a7d1a9b 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000003a8bfc78 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346db1 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000032346106 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000323435f2 2025.03.31 19:14:06.718207 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:06.722140 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:07.309489 [ 3425 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:07.675983 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:07.676576 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:08.307560 [ 3606 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {5b6c3ffa-16e7-43ca-beaa-b3ad04cd266b::202503_1_111_22}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:08.310157 [ 3402 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:08.752700 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:08.756698 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:08.864597 [ 19142 ] {44347bba-ca1c-4daf-9c58-0aca7512fbf9} 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.10457.altinitytest (altinity build)) (from [::1]:37860) (comment: 02319_quantile_interpolated_weighted.sql) (in query: SELECT quantileInterpolatedWeighted(1.0)(a, 1), quantileInterpolatedWeighted(1.0)(b, 2), quantileInterpolatedWeighted(1.0)(c, 3) FROM decimal WHERE a >= 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:08.868884 [ 19142 ] {44347bba-ca1c-4daf-9c58-0aca7512fbf9} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:08.949044 [ 19288 ] {370658bf-b6ac-4fec-b012-974fdeb7c281} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44882) (comment: 02319_quantile_interpolated_weighted.sql) (in query: DROP DATABASE IF EXISTS test_y5y433v2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:14:08.951521 [ 19288 ] {370658bf-b6ac-4fec-b012-974fdeb7c281} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:08.979965 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:08.980542 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:09.310778 [ 3374 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:09.417264 [ 19199 ] {c593b80d-03a8-4c86-80a8-65f77e584909} executeQuery: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44844) (comment: 03062_analyzer_join_engine_missing_column.sql) (in query: CREATE TABLE test (`TOPIC` String, `PARTITION` UInt64, `OFFSET` UInt64, `ID` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_03062', 'r2') ORDER BY (TOPIC, PARTITION, OFFSET) SETTINGS index_granularity = 45105, min_bytes_for_wide_part = 1066805178, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 96611645, compact_parts_max_granules_to_buffer = 142, compact_parts_merge_max_bytes_to_prefetch_part = 22349345, merge_max_block_size = 18081, old_parts_lifetime = 424., 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 = 7892027896, index_granularity_bytes = 24394029, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 45289, primary_key_compress_block_size = 9361), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:09.419472 [ 19199 ] {c593b80d-03a8-4c86-80a8-65f77e584909} TCPHandler: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:09.535311 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:09.539291 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:10.187412 [ 19199 ] {d899c7f0-6eb7-4e58-9b34-62b924b17d19} executeQuery: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44846) (comment: 01773_min_max_time_system_parts_datetime64.sql) (in query: CREATE TABLE test (`time` DateTime64(3)) ENGINE = MergeTree PARTITION BY toStartOfInterval(time, toIntervalYear(2)) ORDER BY tuple() SETTINGS index_granularity = 38391, min_bytes_for_wide_part = 983726449, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 72, min_bytes_for_full_part_storage = 186693699, compact_parts_max_bytes_to_buffer = 59317208, compact_parts_max_granules_to_buffer = 41, compact_parts_merge_max_bytes_to_prefetch_part = 32453187, merge_max_block_size = 23690, 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 = 1628194905, index_granularity_bytes = 17266204, concurrent_part_removal_threshold = 49, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 45256, primary_key_compress_block_size = 94799), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:10.190776 [ 19199 ] {d899c7f0-6eb7-4e58-9b34-62b924b17d19} TCPHandler: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:10.311383 [ 3349 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:10.334812 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:10.335422 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:11.041205 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:11.041697 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:11.312059 [ 3442 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:12.140356 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:12.143474 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:12.312612 [ 3301 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:12.381164 [ 19260 ] {5c10f21c-3d31-42f1-9374-52a714ff2118} 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.10457.altinitytest (altinity build)) (from [::1]:44854) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:12.384679 [ 19260 ] {5c10f21c-3d31-42f1-9374-52a714ff2118} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:13.099285 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:13.102776 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:13.366387 [ 3289 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:13.789297 [ 3778 ] {c89c7fef-6a25-44e6-adbf-d924118e8081} ExternalDictionariesLoader: Could not load external dictionary 'eb0bee69-c4d6-4aa8-9162-ee8c0b6aca57', next update is scheduled at 2025-03-31 19:14:16: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column key): (while reading from part /var/lib/clickhouse/store/05c/05cb482a-a2b0-479d-9f93-6f8608549238/all_1_1_0/ in table test_1.dicttbl (05cb482a-a2b0-479d-9f93-6f8608549238) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003074f71a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003074ef60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003074b4d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x0000000030729b4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003072ac6f 11. DB::ReadBuffer::next() @ 0x00000000095afaaf 12. ./src/IO/ReadBuffer.h:106: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x00000000320d87d8 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320dcb2e 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320dd6ed 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032794d07 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 @ 0x00000000326328f0 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>>>*) @ 0x0000000039c6dc7d 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>>&) @ 0x0000000039cc67d1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c92952 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cb6136 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cae873 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d29606 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfa10d4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b750 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:13.793701 [ 3830 ] {c89c7fef-6a25-44e6-adbf-d924118e8081} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column key): (while reading from part /var/lib/clickhouse/store/05c/05cb482a-a2b0-479d-9f93-6f8608549238/all_1_1_0/ in table test_1.dicttbl (05cb482a-a2b0-479d-9f93-6f8608549238) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): In scope SELECT dictGetString(concat('test_1', '.dict'), 'value_default', toUInt64(12)). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44852) (comment: 01043_dictionary_attribute_properties_values.sql) (in query: SELECT dictGetString(concat('test_1', '.dict'), 'value_default', toUInt64(12))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003074f71a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003074ef60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003074b4d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x0000000030729b4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003072ac6f 11. DB::ReadBuffer::next() @ 0x00000000095afaaf 12. ./src/IO/ReadBuffer.h:106: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x00000000320d87d8 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320dcb2e 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320dd6ed 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032794d07 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 @ 0x00000000326328f0 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>>>*) @ 0x0000000039c6dc7d 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>>&) @ 0x0000000039cc67d1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c92952 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cb6136 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cae873 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d29606 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfa10d4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b750 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 2025.03.31 19:14:13.796314 [ 3830 ] {c89c7fef-6a25-44e6-adbf-d924118e8081} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column key): (while reading from part /var/lib/clickhouse/store/05c/05cb482a-a2b0-479d-9f93-6f8608549238/all_1_1_0/ in table test_1.dicttbl (05cb482a-a2b0-479d-9f93-6f8608549238) located on disk default of type local, from mark 0 with max_rows_to_read = 1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder): In scope SELECT dictGetString(concat('test_1', '.dict'), 'value_default', toUInt64(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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000003074f71a 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003074ef60 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000003074b4d1 9. ./src/IO/AsynchronousReader.h:48: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x0000000030729b4e 10. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:0: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x000000003072ac6f 11. DB::ReadBuffer::next() @ 0x00000000095afaaf 12. ./src/IO/ReadBuffer.h:106: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x00000000320d87d8 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320dcb2e 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:0: non-virtual thunk to DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x00000000320dd6ed 15. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000032794d07 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 @ 0x00000000326328f0 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>>>*) @ 0x0000000039c6dc7d 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>>&) @ 0x0000000039cc67d1 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000039c92952 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x0000000039cb6136 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x0000000039cae873 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:165: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x0000000039d29606 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000003bfa10d4 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:195: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b750 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 26. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 27. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 30. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 31. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 2025.03.31 19:14:13.970733 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:13.974305 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:14.366921 [ 3269 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:15.029524 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:15.032849 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:15.256442 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:15.257074 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:15.367528 [ 3237 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:15.655777 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:15.744509 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:16.368108 [ 3208 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:16.792449 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:16.796382 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:17.204231 [ 15299 ] {06fadbd4-60ee-4b64-bd75-348e80a9f09f} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44912) (comment: 01093_cyclic_defaults_filimonov.sql) (in query: CREATE TABLE test ( `a0` UInt64 DEFAULT a1 + 1, `a1` UInt64 DEFAULT a0 + 1, `a2` UInt64 DEFAULT a3 + a4, `a3` UInt64 DEFAULT a2 + 1, `a4` UInt64 ALIAS a3 + 1 ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035732484 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035733bc8 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000035737d19 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 19. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000035637600 20. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563c8cb 21. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380e8989 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034896358 23. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 24. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 2025.03.31 19:14:17.205875 [ 15299 ] {06fadbd4-60ee-4b64-bd75-348e80a9f09f} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035732484 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035733bc8 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000035737d19 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 19. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000035637600 20. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563c8cb 21. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380e8989 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034896358 23. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 24. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 25. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 26. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 2025.03.31 19:14:17.368838 [ 3521 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:17.538981 [ 19199 ] {f392ac11-bca7-4696-8590-9032c3c5c90d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=734). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44880) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:17.542064 [ 19199 ] {f392ac11-bca7-4696-8590-9032c3c5c90d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:17.708543 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:17.709105 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:18.369495 [ 3190 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:18.540466 [ 15299 ] {c2ac4ef6-6396-49a1-a15c-b773587f4b45} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44912) (comment: 01093_cyclic_defaults_filimonov.sql) (in query: CREATE TABLE pythagoras ( `a` Float64 DEFAULT sqrt((c * c) - (b * b)), `b` Float64 DEFAULT sqrt((c * c) - (a * a)), `c` Float64 DEFAULT sqrt((a * a) + (b * b)) ) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035732484 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035733bc8 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 20. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 21. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 22. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 23. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 24. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 25. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000035737d19 26. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 27. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000035637600 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563c8cb 29. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380e8989 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034896358 31. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 2025.03.31 19:14:18.542565 [ 15299 ] {c2ac4ef6-6396-49a1-a15c-b773587f4b45} TCPHandler: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035732484 5. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035733bc8 6. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 7. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 8. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 9. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 10. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 11. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 12. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 13. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 14. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 15. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 16. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 17. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 18. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 19. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 20. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 21. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 22. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000035734392 23. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x000000003573849a 24. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 25. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000035737d19 26. ./build_docker/./src/Interpreters/QueryNormalizer.cpp:0: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x00000000357343a5 27. ./src/Interpreters/QueryNormalizer.h:0: DB::TreeRewriter::normalize(std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, std::unordered_set, std::equal_to, std::allocator> const&, bool, DB::Settings const&, bool, std::shared_ptr, bool) @ 0x0000000035637600 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000003563c8cb 29. ./build_docker/./src/Storages/ColumnsDescription.cpp:985: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x00000000380e8989 30. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034896358 31. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 2025.03.31 19:14:18.589683 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:18.590323 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:19.036941 [ 19200 ] {219e1f42-2bbf-4077-b895-bea850a98e10} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=734). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:44922) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:19.039569 [ 19200 ] {219e1f42-2bbf-4077-b895-bea850a98e10} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:19.370421 [ 3164 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:19.762993 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:19.765978 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:20.371106 [ 3127 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:20.422139 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:20.422896 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:21.065892 [ 15299 ] {ba7a2a37-58e1-4f1d-b389-e31114c089bb} 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.10457.altinitytest (altinity build)) (from [::1]:47950) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:21.069549 [ 15299 ] {ba7a2a37-58e1-4f1d-b389-e31114c089bb} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:21.371712 [ 3113 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:21.704172 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:21.704777 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:21.871090 [ 4187 ] {25834eec-5aa0-434e-812f-4497cdffb64b} 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.10457.altinitytest (altinity build)) (from [::1]:47958) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:21.874052 [ 4187 ] {25834eec-5aa0-434e-812f-4497cdffb64b} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:22.372298 [ 3084 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:22.854878 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:22.897082 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:23.372857 [ 3066 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:23.556071 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:23.560341 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:24.019712 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:24.022951 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:24.373427 [ 3040 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:24.535203 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:24.535758 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:25.374312 [ 3499 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:25.447456 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:25.452356 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:26.289740 [ 19260 ] {ff83b008-4c48-4fe0-a4c5-073fc354efa3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47966) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:26.293186 [ 19260 ] {ff83b008-4c48-4fe0-a4c5-073fc354efa3} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:26.375008 [ 3489 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:26.609053 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:26.613200 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:27.069643 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:27.073214 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:27.202680 [ 19260 ] {e39b6dea-124b-4788-9734-5770d563934c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47974) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:27.206020 [ 19260 ] {e39b6dea-124b-4788-9734-5770d563934c} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:27.375933 [ 3463 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:27.945237 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:27.948729 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:28.376584 [ 3443 ] {} test_ky6katkn.byte_identical_r1 (311be05f-6e5e-4acc-9d75-8caeaa065d15): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_ky6katkn/test_00721/byte_identical/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:28.936834 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:28.941074 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:29.086396 [ 2854 ] {15455394-30ed-4a81-9105-e689cbaf2429} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:49636) (comment: 00721_force_by_identical_result_after_merge_zookeeper_long.sql) (in query: DROP DATABASE IF EXISTS test_ky6katkn ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:14:29.088602 [ 2854 ] {15455394-30ed-4a81-9105-e689cbaf2429} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:30.013594 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:30.016892 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:30.260338 [ 19260 ] {1fe3dece-e825-48de-859f-bcd4c3a2f6b6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47980) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:30.263724 [ 19260 ] {1fe3dece-e825-48de-859f-bcd4c3a2f6b6} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:31.068263 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:31.071207 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:32.268510 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:32.274036 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:32.546944 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:32.547562 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:33.139858 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:33.143780 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:33.525199 [ 19260 ] {345bf381-84bd-40b5-9537-75c8d81d0abe} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48696) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:33.528469 [ 19260 ] {345bf381-84bd-40b5-9537-75c8d81d0abe} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:14:33.547510 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:33.558744 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:33.989180 [ 3605 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::0_1_11_1_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.059191 [ 3605 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::0_1_11_1_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.064953 [ 4187 ] {faafc176-37fc-403e-a5be-56843bc2cc85} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_15.txt' with part '0_1_11_1_14' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48680) (comment: 01055_compact_parts.sql) (in query: alter table mt_compact update b = 42 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfc29f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfc005 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:34.068019 [ 4187 ] {faafc176-37fc-403e-a5be-56843bc2cc85} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_15.txt' with part '0_1_11_1_14' reason: 'Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&, String&) @ 0x0000000039bfc29f 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfc005 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:34.091150 [ 3602 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::1_2_12_1_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.096949 [ 3601 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::3_4_4_1_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.097152 [ 3602 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::1_2_12_1_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.104744 [ 3601 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::3_4_4_1_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.113566 [ 3610 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::4_5_5_1_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.117293 [ 3610 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::4_5_5_1_15} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.151517 [ 3608 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::3_4_4_1_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.152231 [ 3608 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::3_4_4_1_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.178587 [ 19311 ] {6e1c9225-243b-40f7-a07e-b72b47898bf9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51186) (comment: 01055_compact_parts.sql) (in query: DROP DATABASE IF EXISTS test_phv06hqv ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 2025.03.31 19:14:34.180969 [ 19311 ] {6e1c9225-243b-40f7-a07e-b72b47898bf9} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000034930e1c 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 13. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 14. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 19. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 20. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 21. ? @ 0x00007f038ce47ac3 22. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.250341 [ 3596 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::6_7_7_1_15} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.250958 [ 3596 ] {e833ef84-51fc-44a7-b5b0-0ec5e2f145ec::6_7_7_1_15} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.554268 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.557936 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.860773 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:34.864105 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:35.092166 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:35.095617 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:35.600528 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:35.604154 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:36.432031 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:36.435875 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:36.495268 [ 19311 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:36.936408 [ 19260 ] {ced81e6f-a1d8-4668-8218-32c862998682} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48704) (comment: 00092_union_race_conditions_3.sh) (in query: SELECT * FROM (SELECT * FROM system.numbers_mt LIMIT 111) LIMIT 55;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:36.939760 [ 19260 ] {ced81e6f-a1d8-4668-8218-32c862998682} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:37.088444 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:37.632208 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:37.636152 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:38.169904 [ 19203 ] {b6e884b2-eeae-430d-b7ac-b213e607304b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51216) (comment: 01755_shard_pruning_with_literal.sql) (in query: DROP DATABASE IF EXISTS test_pcbu2wsz ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:14:38.172332 [ 19203 ] {b6e884b2-eeae-430d-b7ac-b213e607304b} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:38.203790 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:38.818571 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:38.822899 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:39.270542 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:39.972546 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:39.976583 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:40.287378 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:40.291053 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:40.294124 [ 19200 ] {6887a1f8-e0f5-45eb-9464-0b13e8fb9dcc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=738). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47954) (comment: 00411_long_accurate_number_comparison_float.sql) (in query: SELECT '-1', '104.000000000', -1 = 104.000000000, -1 != 104.000000000, -1 < 104.000000000, -1 <= 104.000000000, -1 > 104.000000000, -1 >= 104.000000000, 104.000000000 = -1, 104.000000000 != -1, 104.000000000 < -1, 104.000000000 <= -1, 104.000000000 > -1, 104.000000000 >= -1 , toInt8(-1) = 104.000000000, toInt8(-1) != 104.000000000, toInt8(-1) < 104.000000000, toInt8(-1) <= 104.000000000, toInt8(-1) > 104.000000000, toInt8(-1) >= 104.000000000, 104.000000000 = toInt8(-1), 104.000000000 != toInt8(-1), 104.000000000 < toInt8(-1), 104.000000000 <= toInt8(-1), 104.000000000 > toInt8(-1), 104.000000000 >= toInt8(-1) , toInt16(-1) = 104.000000000, toInt16(-1) != 104.000000000, toInt16(-1) < 104.000000000, toInt16(-1) <= 104.000000000, toInt16(-1) > 104.000000000, toInt16(-1) >= 104.000000000, 104.000000000 = toInt16(-1), 104.000000000 != toInt16(-1), 104.000000000 < toInt16(-1), 104.000000000 <= toInt16(-1), 104.000000000 > toInt16(-1), 104.000000000 >= toInt16(-1) , toInt32(-1) = 104.000000000, toInt32(-1) != 104.000000000, toInt32(-1) < 104.000000000, toInt32(-1) <= 104.000000000, toInt32(-1) > 104.000000000, toInt32(-1) >= 104.000000000, 104.000000000 = toInt32(-1), 104.000000000 != toInt32(-1), 104.000000000 < toInt32(-1), 104.000000000 <= toInt32(-1), 104.000000000 > toInt32(-1), 104.000000000 >= toInt32(-1) , toInt64(-1) = 104.000000000, toInt64(-1) != 104.000000000, toInt64(-1) < 104.000000000, toInt64(-1) <= 104.000000000, toInt64(-1) > 104.000000000, toInt64(-1) >= 104.000000000, 104.000000000 = toInt64(-1), 104.000000000 != toInt64(-1), 104.000000000 < toInt64(-1), 104.000000000 <= toInt64(-1), 104.000000000 > toInt64(-1), 104.000000000 >= toInt64(-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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:40.297956 [ 19200 ] {6887a1f8-e0f5-45eb-9464-0b13e8fb9dcc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=738). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:40.337267 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:41.076269 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:41.076851 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:41.385973 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:41.449486 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:41.510566 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:42.278169 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:42.278902 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:42.521306 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:43.298161 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:43.301220 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:43.315666 [ 19203 ] {8fb922a5-37fd-435e-89a1-c40ab3b56937} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:48750) (comment: 02940_variant_text_deserialization.sql) (in query: select 'IPv6';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:43.318067 [ 19203 ] {8fb922a5-37fd-435e-89a1-c40ab3b56937} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:43.586696 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:44.415698 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:44.419050 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:44.819671 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:45.367750 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:45.371816 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:45.762926 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:45.766474 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:45.860731 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:46.582042 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:46.582596 [ 3599 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:46.928273 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:46.932472 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:46.970907 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:47.520361 [ 4187 ] {97f51537-01d2-474e-826a-c4f15b46ee33} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47870) (comment: 01018_empty_aggregation_filling.sql) (in query: SELECT avgOrNullIf(x, x > 0) FROM (SELECT 1 AS x);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:47.523602 [ 4187 ] {97f51537-01d2-474e-826a-c4f15b46ee33} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:14:47.671998 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:47.672643 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:48.065678 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:48.350348 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:48.353623 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:48.842551 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:48.920065 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:49.126082 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:49.267918 [ 4187 ] {6b5118c5-269d-4506-9331-bb7adb695b4a} executeQuery: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47920) (comment: 03144_fuzz_quoted_type_name.sql) (in query: create table t (x Array(`ab`)) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:249: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x00000000323a5943 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000323a254e 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000003239ba17 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:104: DB::create(std::shared_ptr const&) @ 0x00000000323622f8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003235e65a 9. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a2571 10. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000003239ba17 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:557: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034892bfe 12. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 13. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:14:49.269422 [ 4187 ] {6b5118c5-269d-4506-9331-bb7adb695b4a} TCPHandler: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:249: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x00000000323a5943 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000323a254e 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000003239ba17 7. ./build_docker/./src/DataTypes/DataTypeArray.cpp:104: DB::create(std::shared_ptr const&) @ 0x00000000323622f8 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000003235e65a 9. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:0: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x00000000323a2571 10. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000003239ba17 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:557: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034892bfe 12. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 13. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 18. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 22. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 23. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 24. ? @ 0x00007f038ce47ac3 25. ? @ 0x00007f038ced9850 2025.03.31 19:14:49.443662 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:49.448103 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:49.842282 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:49.845953 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:50.034648 [ 12294 ] {e006944d-887c-4904-b426-ebefb2f79504} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47926) (comment: 02718_cli_dashed_options_parsing.sh) (in query: CREATE TABLE test (d Date, s String) ENGINE = MergeTree(d, s, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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*&&, char const*&&, String&&, long&, String&&) @ 0x0000000020096687 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094fb3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000002018330a 9. ./src/IO/BufferWithOwnMemory.h:159: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x00000000202008f3 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x00000000201fe90d 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000002058d488 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&) @ 0x0000000032ec0ea3 13. ./build_docker/./src/Disks/DiskLocal.cpp:0: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000032ea9598 14. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:306: DB::MergeTreeData::initializeDirectoriesAndFormatVersion(String const&, bool, String const&, bool) @ 0x000000003969bc1e 15. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: 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>) @ 0x000000003a2c1d48 16. ./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>&&) @ 0x000000003a2bfe8f 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:14:50.037188 [ 12294 ] {e006944d-887c-4904-b426-ebefb2f79504} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1048639 bytes), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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*&&, char const*&&, String&&, long&, String&&) @ 0x0000000020096687 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094fb3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ff7763d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ff721c4 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000002018330a 9. ./src/IO/BufferWithOwnMemory.h:159: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x00000000202008f3 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x00000000201fe90d 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000002058d488 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&) @ 0x0000000032ec0ea3 13. ./build_docker/./src/Disks/DiskLocal.cpp:0: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000032ea9598 14. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:306: DB::MergeTreeData::initializeDirectoriesAndFormatVersion(String const&, bool, String const&, bool) @ 0x000000003969bc1e 15. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: 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>) @ 0x000000003a2c1d48 16. ./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>&&) @ 0x000000003a2bfe8f 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 21. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 22. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:14:50.201586 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:50.509552 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:50.510376 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:50.739373 [ 4187 ] {829aed73-782f-4c98-94b1-47bd7610bf55} executeQuery: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47920) (comment: 03144_fuzz_quoted_type_name.sql) (in query: create table t (x `ab`) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:249: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x00000000323a5943 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000323a254e 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000003239ba17 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:557: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034892bfe 8. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 9. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:14:50.740922 [ 4187 ] {829aed73-782f-4c98-94b1-47bd7610bf55} TCPHandler: Code: 50. DB::Exception: Unknown data type family: ab. (UNKNOWN_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:249: std::function (std::shared_ptr const&)> const* DB::DataTypeFactory::findCreatorByName(String const&) const @ 0x00000000323a5943 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:848: ? @ 0x00000000323a254e 6. ./build_docker/./src/DataTypes/DataTypeFactory.cpp:74: DB::DataTypeFactory::get(std::shared_ptr const&) const @ 0x000000003239ba17 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:557: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034892bfe 8. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 9. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:14:50.891900 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:50.895133 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:50.957480 [ 4187 ] {8d9b4980-5e88-4c6e-9d5e-876e520e2b42} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39106) (comment: 03144_fuzz_quoted_type_name.sql) (in query: DROP DATABASE IF EXISTS test_rgkwaln4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:14:50.960717 [ 4187 ] {8d9b4980-5e88-4c6e-9d5e-876e520e2b42} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:50.977625 [ 19142 ] {70b3da0b-3221-44b6-b571-dec154be1b5f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39122) (comment: 03144_fuzz_quoted_type_name.sql) (in query: DROP DATABASE IF EXISTS test_rgkwaln4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:14:50.980231 [ 19142 ] {70b3da0b-3221-44b6-b571-dec154be1b5f} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:51.231342 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:51.234837 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:51.338636 [ 4187 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:51.775254 [ 12294 ] {86412405-5578-4b47-a3ef-869b2609ad54} executeQuery: Code: 60. DB::Exception: Table test_1.test does not exist. (UNKNOWN_TABLE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35892) (comment: 02718_cli_dashed_options_parsing.sh) (in query: DROP TABLE test), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b04a61 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003398fd73 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a5247 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349255bb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:14:51.777993 [ 12294 ] {86412405-5578-4b47-a3ef-869b2609ad54} TCPHandler: Code: 60. DB::Exception: Table test_1.test 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000032b04a61 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:431: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x000000003398fd73 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000339a5247 7. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000349255bb 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 14. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:14:52.062882 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:52.067058 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:52.511301 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:53.270971 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:53.275383 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:53.661027 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:54.369592 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:54.372864 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:54.809699 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:55.051710 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:55.055449 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:55.411500 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:55.415476 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:55.913227 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:56.543045 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:56.548474 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:56.991578 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:56.995033 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:57.009404 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:57.406107 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:57.406811 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 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) @ 0x0000000034f6039a 9. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2185: DB::MutateTask::prepare() @ 0x0000000039e65536 10. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 11. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aa57c 12. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 13. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 18. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:58.059684 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:58.168979 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:58.172338 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:58.339610 [ 12294 ] {ba9e933f-b39a-49b9-8d93-c46138129cd9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:35974) (comment: 00331_final_and_prewhere_condition_ver_column.sql) (in query: SELECT count(ver) FROM myRMT FINAL PREWHERE ver > '2000-01-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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25da5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c03fa33 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf9e973 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 26. ? @ 0x00007f038ce47ac3 27. ? @ 0x00007f038ced9850 2025.03.31 19:14:58.343473 [ 12294 ] {ba9e933f-b39a-49b9-8d93-c46138129cd9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x0000000039d25da5 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000003bf9245a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:72: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000003c03fa33 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000003bf9e973 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::MergeTreeSelectProcessor::read() @ 0x0000000039d1b4e0 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000003bf45b25 18. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 19. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f9a3 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 24. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 26. ? @ 0x00007f038ce47ac3 27. ? @ 0x00007f038ced9850 2025.03.31 19:14:58.433313 [ 12294 ] {6c325d4f-e5f3-49cc-a099-d66cc0eacace} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:39196) (comment: 00331_final_and_prewhere_condition_ver_column.sql) (in query: DROP DATABASE IF EXISTS test_6u86ajyq ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:14:58.435869 [ 12294 ] {6c325d4f-e5f3-49cc-a099-d66cc0eacace} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:58.470105 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:58.470682 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:58.998940 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:59.003231 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:59.162902 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:14:59.523686 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:59.527990 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:59.923502 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:14:59.924021 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:00.233808 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:01.135734 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:01.140110 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:01.395528 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:01.765392 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:01.769642 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:02.624859 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:02.955448 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:02.956212 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:03.238610 [ 12294 ] {24644f85-845f-4693-ae13-51247c3e6468} 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.10457.altinitytest (altinity build)) (from [::1]:37142) (comment: 00705_aggregate_states_addition.sql) (in query: SELECT sumMerge(x + y), sumMerge(x), sumMerge(y) FROM (SELECT sumState(a) as x, sumState(b) as y from add_aggregate);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:15:03.242508 [ 12294 ] {24644f85-845f-4693-ae13-51247c3e6468} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:15:03.790095 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:03.790576 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:03.791249 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:04.643203 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:04.643827 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:04.848121 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:05.292453 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:05.295777 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:05.301032 [ 12294 ] {d92e834a-5880-4807-9658-c0bc2589b878} executeQuery: Code: 36. DB::Exception: Cannot materialize column `x` because it doesn't have default expression. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37178) (comment: 02008_materialize_column.sql) (in query: ALTER TABLE tmp MATERIALIZE COLUMN 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:782: DB::MutationsInterpreter::prepare(bool) @ 0x0000000034f851da 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000034f6c929 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000034f69bcc 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854d30 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:05.302803 [ 12294 ] {d92e834a-5880-4807-9658-c0bc2589b878} TCPHandler: Code: 36. DB::Exception: Cannot materialize column `x` because it doesn't have default expression. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:782: DB::MutationsInterpreter::prepare(bool) @ 0x0000000034f851da 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000034f6c929 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000034f69bcc 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854d30 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:05.808149 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:05.811456 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:05.895999 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:06.411460 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:06.415366 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:06.943568 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:06.947837 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:07.120877 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:07.984550 [ 19142 ] {2e76eccb-7a9b-4412-9ba5-becfb589538f} 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.10457.altinitytest (altinity build)) (from [::1]:37128) (comment: 00597_push_down_predicate_long.sql) (in query: SELECT * FROM (SELECT * FROM test_00597 UNION ALL SELECT * FROM test_00597) WHERE id = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:15:07.986190 [ 19142 ] {2e76eccb-7a9b-4412-9ba5-becfb589538f} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d9614 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) @ 0x0000000039a3d525 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) @ 0x000000003bee63e9 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000003bee1d7a 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000003bee1505 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000003bef8b79 11. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2022: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000003befe560 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000034ce1fcd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x0000000034ce19e1 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:15:08.030737 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:08.035641 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:08.191911 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:08.792896 [ 3830 ] {a9de60af-2886-4cbb-a399-1c8843da1053} Context: Server has databases (for example `02265_ordinary_db`) 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.03.31 19:15:08.988403 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:08.991260 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:09.234500 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:09.260400 [ 3830 ] {baaf1722-a2b3-45bf-8a7f-04a6f5d6ca3d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37238) (comment: 02265_rename_join_ordinary_to_atomic.sql) (in query: DROP DATABASE IF EXISTS 02265_atomic_db;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:09.262082 [ 3830 ] {baaf1722-a2b3-45bf-8a7f-04a6f5d6ca3d} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:09.371318 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:09.375173 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:09.570297 [ 3610 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fce196b8-b32c-4319-8cdf-3d340eb025b8::202503_219_267_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:10.307174 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:10.390937 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:10.394970 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:11.096001 [ 12293 ] {20290fe5-2113-4830-8ac7-e12fea237296} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40696) (comment: 01825_type_json_empty_string.sql) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:11.098679 [ 12293 ] {20290fe5-2113-4830-8ac7-e12fea237296} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:11.352536 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:11.356700 [ 3600 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:11.386527 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:11.826814 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:11.827517 [ 3605 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:12.151294 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:12.151872 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:12.451864 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:12.573448 [ 12294 ] {908531f4-754b-4c8b-b329-8b071ce92225} 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.10457.altinitytest (altinity build)) (from [::1]:40716) (comment: 01055_compact_parts.sql) (in query: select * from mt_compact order by a 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:15:12.578952 [ 12294 ] {908531f4-754b-4c8b-b329-8b071ce92225} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:15:12.676070 [ 3830 ] {47ecae86-964b-4208-9b4c-49f089bf2d06} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40830) (comment: 01055_compact_parts.sql) (in query: DROP DATABASE IF EXISTS test_h95hdm8l ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:15:12.678637 [ 3830 ] {47ecae86-964b-4208-9b4c-49f089bf2d06} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:12.697043 [ 5367 ] {} test_h95hdm8l.mt_compact (686080d8-c8ae-4d81-9b1f-7a5a669e9c07): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.03.31 19:15:12.757110 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:12.760875 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:13.374048 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:13.378218 [ 3598 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:13.601431 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:14.178964 [ 5367 ] {} DatabaseCatalog: Cannot drop table test_h95hdm8l.mt_compact (686080d8-c8ae-4d81-9b1f-7a5a669e9c07). Will retry later.: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 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>*) @ 0x00000000397276a1 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>*) @ 0x0000000039720472 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2997: DB::MergeTreeData::dropAllData() @ 0x0000000039736baa 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2cda53 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339b9fe2 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339daaa3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303ec68c 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()() @ 0x00000000303ec46d 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b123d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303eeb6e 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:14.422646 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:14.425902 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:14.453101 [ 3830 ] {bccb5a08-b958-4542-a9d8-cd61c3e4b7b7} executeQuery: Code: 35. DB::Exception: Function arrayZip needs at least one argument; passed 0.: In scope SELECT arrayZip(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40748) (comment: 01045_array_zip.sql) (in query: SELECT arrayZip();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a58cd 4. DB::FunctionArrayZip::getReturnTypeImpl(std::vector> const&) const @ 0x000000001f1542cc 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:15:14.454564 [ 3830 ] {bccb5a08-b958-4542-a9d8-cd61c3e4b7b7} TCPHandler: Code: 35. DB::Exception: Function arrayZip needs at least one argument; passed 0.: In scope SELECT arrayZip(). (TOO_FEW_ARGUMENTS_FOR_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x00000000083a58cd 4. DB::FunctionArrayZip::getReturnTypeImpl(std::vector> const&) const @ 0x000000001f1542cc 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:15:14.655595 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:15.444580 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:15.445260 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:15.815539 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:15.816301 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:15.874827 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:15.956036 [ 3830 ] {13901134-0c58-41ad-a14c-17b16ee87dec} executeQuery: Code: 43. DB::Exception: Argument 1 of function arrayZip must be array. Found String instead.: In scope SELECT arrayZip('a', 'b', 'c'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40748) (comment: 01045_array_zip.sql) (in query: SELECT arrayZip('a', 'b', 'c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionArrayZip::getReturnTypeImpl(std::vector> const&) const @ 0x000000001f154048 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:15:15.958078 [ 3830 ] {13901134-0c58-41ad-a14c-17b16ee87dec} TCPHandler: Code: 43. DB::Exception: Argument 1 of function arrayZip must be array. Found String instead.: In scope SELECT arrayZip('a', 'b', 'c'). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. DB::FunctionArrayZip::getReturnTypeImpl(std::vector> const&) const @ 0x000000001f154048 5. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 10. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 29. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 30. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 31. ? @ 0x00007f038ce47ac3 2025.03.31 19:15:16.337491 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:16.338257 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:16.956080 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:17.647212 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:17.647891 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:18.054579 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:18.090534 [ 3830 ] {b5530fc4-e672-44b0-a928-db9b669deea0} executeQuery: Code: 190. DB::Exception: The argument 1 and argument 2 of function arrayZip have different array sizes: In scope SELECT arrayZip(['a', 'b', 'c'], ['d', 'e', 'f', 'd']). (SIZES_OF_ARRAYS_DONT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40748) (comment: 01045_array_zip.sql) (in query: SELECT arrayZip(['a', 'b', 'c'], ['d', 'e', 'f', 'd']);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x0000000018d92f2d 4. DB::FunctionArrayZip::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f152ab3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:15:18.092247 [ 3830 ] {b5530fc4-e672-44b0-a928-db9b669deea0} TCPHandler: Code: 190. DB::Exception: The argument 1 and argument 2 of function arrayZip have different array sizes: In scope SELECT arrayZip(['a', 'b', 'c'], ['d', 'e', 'f', 'd']). (SIZES_OF_ARRAYS_DONT_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x0000000018d92f2d 4. DB::FunctionArrayZip::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001f152ab3 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 13. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:15:18.195651 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:18.199291 [ 3604 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:18.531048 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:18.535677 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:18.965437 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:18.966378 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:19.126790 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:19.283515 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:19.287238 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:20.186886 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:20.244701 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:20.247869 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:20.851089 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:20.854971 [ 3609 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:21.286665 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:21.651080 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:21.654840 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:22.034413 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:22.038157 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:22.364300 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:23.174052 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:23.178400 [ 3610 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:23.420351 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:23.544751 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:23.548462 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:23.954271 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:23.954913 [ 3607 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:24.381257 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:24.385418 [ 3606 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:24.455904 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:25.069244 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:25.074520 [ 3596 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:25.513343 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:25.978023 [ 19288 ] {c09ad7e6-e723-413b-9d68-598c7a625f6f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38808) (comment: 02017_bit_shift_left_for_string_integer.sql) (in query: SELECT 24,toFixedString('Hello', 10), bin(bitShiftLeft(toFixedString('Hello', 10), 24));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:15:25.980860 [ 19288 ] {c09ad7e6-e723-413b-9d68-598c7a625f6f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:15:26.185119 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:26.185990 [ 3602 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:26.741033 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:27.150492 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:27.154308 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:27.587925 [ 19200 ] {7b7cfe78-93dc-4ff1-bd66-60b3e18875ed} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38924) (comment: 01032_cityHash64_for_UUID.sql) (in query: SELECT (SELECT count() FROM t_uuid WHERE cityHash64(reinterpretAsString(x)) = cityHash64(x) and length(reinterpretAsString(x)) = 16) = (SELECT count() AS c2 FROM t_uuid WHERE length(reinterpretAsString(x)) = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:15:27.590737 [ 19200 ] {7b7cfe78-93dc-4ff1-bd66-60b3e18875ed} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:15:27.803217 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:28.330447 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:28.330986 [ 3595 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:28.892327 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:29.187871 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:29.191505 [ 3597 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:29.463264 [ 19200 ] {cad6b349-c2d1-479e-b1e5-d326cdaed981} 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.10457.altinitytest (altinity build)) (from [::1]:38970) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT keyword FROM system.keywords ELSE null('keyword String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:15:29.486903 [ 19200 ] {cad6b349-c2d1-479e-b1e5-d326cdaed981} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:15:30.019752 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:30.202275 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:30.206371 [ 3603 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:30.514388 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:30.514985 [ 3601 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:31.132131 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:31.635238 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} MutatePlainMergeTreeTask: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:31.638764 [ 3608 ] {c271963a-b599-4f9d-bb51-84a1e18190fd::1_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 12000000 microseconds per block (of size 4): while executing 'FUNCTION if(and(equals(p, 1), equals(_partition_id, '1')) :: 5, _CAST(sleepEachRow(3), 'UInt64') :: 3, i :: 1) -> if(and(equals(p, 1), equals(_partition_id, '1')), _CAST(sleepEachRow(3), 'UInt64'), i) UInt64 : 4'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, unsigned long&, unsigned long&) @ 0x000000001c0bae97 4. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000001c0baadd 5. DB::FunctionSleep<(DB::FunctionSleepVariant)1>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001c0b9251 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x00000000083cd03f 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ColumnFunction::reduce() const @ 0x0000000037431850 12. ./build_docker/./src/Columns/ColumnFunction.cpp:0: DB::ColumnFunction::reduce() const @ 0x0000000037430ae4 13. ./build_docker/./src/Columns/MaskOperations.cpp:0: DB::maskedExecute(DB::ColumnWithTypeAndName&, DB::PODArray, 63ul, 64ul> const&, DB::MaskInfo const&) @ 0x0000000038048e45 14. DB::(anonymous namespace)::FunctionIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125bc806 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce7db 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb2ca 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:124: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000033a12cbe 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000003b7e7a44 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000020ac9644 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000003ae2264b 23. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:0: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000003aea3124 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000039e5699b 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x0000000039ed1cc2 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x0000000039ec2072 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x0000000039e62fff (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:15:32.222016 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:33.298257 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:33.609208 [ 19203 ] {4e191d7f-902c-4904-8fd8-1e7a44eb5172} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46112) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT keyword FROM system.keywords ELSE null('keyword String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:15:33.708138 [ 19203 ] {4e191d7f-902c-4904-8fd8-1e7a44eb5172} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:15:34.349466 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:35.418711 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:35.663540 [ 19260 ] {8331288b-1307-4b4a-bb93-d6086401035d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=737). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46164) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT keyword FROM system.keywords ELSE null('keyword String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:15:35.681071 [ 19260 ] {8331288b-1307-4b4a-bb93-d6086401035d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:15:36.561433 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:37.619172 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:37.927745 [ 19260 ] {3a8dcffe-c9f4-40f1-986b-0d736915924e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46200) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT keyword FROM system.keywords ELSE null('keyword String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:15:37.947880 [ 19260 ] {3a8dcffe-c9f4-40f1-986b-0d736915924e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:15:38.745523 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:40.043478 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:41.101544 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:42.274807 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:43.327449 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:43.802141 [ 19142 ] {220e7fcc-834f-4b19-b6e3-0964327c3302} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:49022) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT keyword FROM system.keywords ELSE null('keyword String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:15:43.820951 [ 19142 ] {220e7fcc-834f-4b19-b6e3-0964327c3302} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae61af7 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 12. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:15:44.393485 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:45.436120 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:46.566112 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:47.634864 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:47.656919 [ 19142 ] {184feddc-1db7-45f7-8d26-aa22a76e668d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:49098) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT keyword FROM system.keywords ELSE null('keyword String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:15:47.675284 [ 19142 ] {184feddc-1db7-45f7-8d26-aa22a76e668d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:15:48.768990 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:49.823915 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:51.095393 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:52.194392 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:53.279770 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:54.401534 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:55.585072 [ 19203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:56.747530 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:57.915407 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:15:59.021152 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:00.153153 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:01.360008 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:02.397796 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:03.532017 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:04.610623 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:05.659752 [ 19200 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:06.705514 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:07.028720 [ 19203 ] {eb59c40a-986f-4951-a37e-cd2f31b48c1d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58720) (comment: 02983_empty_map.sql) (in query: DROP DATABASE IF EXISTS test_e0el2r0a ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:16:07.031204 [ 19203 ] {eb59c40a-986f-4951-a37e-cd2f31b48c1d} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:16:07.120415 [ 19142 ] {44340e01-7407-40be-bbde-9562a5b4c7e6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58736) (comment: 02983_empty_map.sql) (in query: DROP DATABASE IF EXISTS test_e0el2r0a ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:16:07.124302 [ 19142 ] {44340e01-7407-40be-bbde-9562a5b4c7e6} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:16:07.808946 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:08.874965 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:09.916566 [ 26817 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:10.407623 [ 12294 ] {ae982b8d-d179-4f6a-be45-10d7a80818ee} 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.10457.altinitytest (altinity build)) (from [::1]:40574) (comment: 02021_exponential_sum_shard.sql) (in query: WITH number % 10 = 0 AS value, number AS time SELECT exponentialMovingAverage(1)(value, time) AS exp_smooth FROM remote('127.0.0.{1..10}', numbers_mt(10000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:16:10.486329 [ 19142 ] {skwggxbhgn} BackupsWorker: Failed to make backup S3(s3_conn, 'backups/test_1/data_no_native_copy'): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000031821374 8. ./build_docker/./src/Backups/BackupsWorker.cpp:686: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000003171d781 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x000000003171722e 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170a3d8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000317082e8 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a62ef8 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:16:10.492438 [ 12294 ] {ae982b8d-d179-4f6a-be45-10d7a80818ee} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:16:10.543036 [ 19142 ] {skwggxbhgn} 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.10457.altinitytest (altinity build)) (from [::1]:54064) (comment: 02801_backup_native_copy.sh) (in query: BACKUP TABLE data TO S3(s3_conn, 'backups/test_1/data_no_native_copy') SETTINGS allow_s3_native_copy=false), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000031821374 8. ./build_docker/./src/Backups/BackupsWorker.cpp:686: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000003171d781 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x000000003171722e 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170a3d8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000317082e8 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a62ef8 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 2025.03.31 19:16:10.545413 [ 19142 ] {skwggxbhgn} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000031821374 8. ./build_docker/./src/Backups/BackupsWorker.cpp:686: DB::BackupsWorker::buildFileInfosForBackupEntries(std::shared_ptr const&, std::vector>, std::allocator>>> const&, DB::ReadSettings const&, std::shared_ptr, std::shared_ptr) @ 0x000000003171d781 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::doBackup(std::shared_ptr&, std::shared_ptr const&, String const&, String const&, DB::BackupInfo const&, DB::BackupSettings, std::shared_ptr, std::shared_ptr const&, std::shared_ptr) @ 0x000000003171722e 10. ./build_docker/./src/Backups/BackupsWorker.cpp:0: DB::BackupsWorker::startMakingBackup(std::shared_ptr const&, std::shared_ptr const&) @ 0x000000003170a3d8 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000317082e8 12. ./build_docker/./src/Interpreters/InterpreterBackupQuery.cpp:0: DB::InterpreterBackupQuery::execute() @ 0x0000000035a62ef8 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 16. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 20. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 21. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 2025.03.31 19:16:11.096795 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:11.477631 [ 19288 ] {275138a0-a73f-4c52-bfd1-0b73da8578b3} 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]:39996). (NETWORK_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39996) (comment: 02021_exponential_sum_shard.sql) (in query: SELECT exponentialMovingAverage(1)((`__table1`.`number` % 10) = 0, `__table1`.`number`) AS `exp_smooth` FROM numbers_mt(10000) AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c1518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ec297 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abc00bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7715 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:16:11.481636 [ 19288 ] {275138a0-a73f-4c52-bfd1-0b73da8578b3} 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]:39996). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c1518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ec297 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000003abe999a 6. ./src/Core/Block.h:25: DB::TCPHandler::sendLogs() @ 0x000000003abbb56a 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab956a8 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:16:11.488849 [ 19288 ] {275138a0-a73f-4c52-bfd1-0b73da8578b3} 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]:39996). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 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&&) @ 0x00000000204bcabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x00000000204c1518 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:0: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000003a7ec297 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000003abc00bd 6. ./contrib/llvm-project/libcxx/include/__mutex_base:253: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7715 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 12. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 13. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 14. ? @ 0x00007f038ce47ac3 15. ? @ 0x00007f038ced9850 2025.03.31 19:16:11.489591 [ 19288 ] {275138a0-a73f-4c52-bfd1-0b73da8578b3} TCPHandler: Client has gone away. 2025.03.31 19:16:12.180931 [ 19142 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:13.296213 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:13.773240 [ 19142 ] {5155884d-3dd3-4813-817b-8f346b725935} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=738). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40612) (comment: 03036_join_filter_push_down_equivalent_sets.sql) (in query: SELECT '--';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:13.788922 [ 19142 ] {5155884d-3dd3-4813-817b-8f346b725935} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=738). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:14.424584 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:15.539699 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:16.511923 [ 3830 ] {a0e74ed2-1f95-4531-b8f1-e93cac3f7f0a} executeQuery: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40650) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: CREATE TABLE test (`id` UInt64, `sum` UInt64, `d` Dynamic) ENGINE = SummingMergeTree(sum) ORDER BY id SETTINGS min_rows_for_wide_part = 100000000000, min_bytes_for_wide_part = 1000000000000, vertical_merge_algorithm_min_rows_to_activate = 10000000000, vertical_merge_algorithm_min_columns_to_activate = 100000000000, index_granularity = 8128, 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 = 87616464, compact_parts_max_bytes_to_buffer = 365409209, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 28292734, merge_max_block_size = 8128, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, min_merge_bytes_to_use_direct_io = 6095395931, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 80308, primary_key_compress_block_size = 71121), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:16.517255 [ 3830 ] {a0e74ed2-1f95-4531-b8f1-e93cac3f7f0a} TCPHandler: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:16.613254 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:17.696878 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:17.862389 [ 3830 ] {2a4c8b2d-7a60-4f86-8707-b306ccc40da3} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40670) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: insert into test select number, 1, number 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:17.864860 [ 3830 ] {2a4c8b2d-7a60-4f86-8707-b306ccc40da3} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 1). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:18.762250 [ 19288 ] {29c15b94-2c8d-442f-a7de-4acabdd167da} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40686) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: insert into test select number, 1, 'str_' || toString(number) from numbers(50000, 100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:18.764918 [ 19288 ] {29c15b94-2c8d-442f-a7de-4acabdd167da} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 1). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:18.824815 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:19.629067 [ 19288 ] {d7b8e411-74fc-47b4-96b1-f41d1f42a05a} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59902) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:16:19.725529 [ 19288 ] {d7b8e411-74fc-47b4-96b1-f41d1f42a05a} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:16:19.872494 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:20.597009 [ 3830 ] {e06105e6-6754-476f-b5c3-7fae85eb55e7} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'sum' in scope SELECT count(), sum FROM test GROUP BY sum ORDER BY sum ASC, count() ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59910) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: select count(), sum from test group by sum order by sum, count()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:16:20.599944 [ 3830 ] {e06105e6-6754-476f-b5c3-7fae85eb55e7} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'sum' in scope SELECT count(), sum FROM test GROUP BY sum ORDER BY sum ASC, count() 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:16:21.021647 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:22.117014 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:22.605983 [ 3830 ] {faa62e7b-0d6a-40e2-b795-6710468e1b95} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59956) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:16:22.608606 [ 3830 ] {faa62e7b-0d6a-40e2-b795-6710468e1b95} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:16:23.151778 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:23.374235 [ 19199 ] {13667c09-1902-4b5d-84c0-404ba0081246} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'sum' in scope SELECT count(), sum FROM test GROUP BY sum ORDER BY sum ASC, count() ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59974) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: select count(), sum from test group by sum order by sum, count()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:16:23.377162 [ 19199 ] {13667c09-1902-4b5d-84c0-404ba0081246} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'sum' in scope SELECT count(), sum FROM test GROUP BY sum ORDER BY sum ASC, count() 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:16:24.249928 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:24.829878 [ 3830 ] {b85b52e3-6e0e-47b3-b04b-8fc7f4fc1e11} executeQuery: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59992) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: CREATE TABLE test (`id` UInt64, `sum` UInt64, `d` Dynamic) ENGINE = SummingMergeTree(sum) ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000000, vertical_merge_algorithm_min_columns_to_activate = 1000000000000, index_granularity = 8128, 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 = 87616464, compact_parts_max_bytes_to_buffer = 365409209, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 28292734, merge_max_block_size = 8128, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, min_merge_bytes_to_use_direct_io = 6095395931, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 80308, primary_key_compress_block_size = 71121), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:24.835179 [ 3830 ] {b85b52e3-6e0e-47b3-b04b-8fc7f4fc1e11} TCPHandler: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:25.347378 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:26.361820 [ 19199 ] {74cf96c8-6e96-408f-adeb-d235b7a5ffff} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60012) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: insert into test select number, 1, number 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:26.364030 [ 19199 ] {74cf96c8-6e96-408f-adeb-d235b7a5ffff} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 1). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:26.408773 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:27.122440 [ 19199 ] {f04b293d-10b7-4ca6-866b-aa1e17abb517} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 1). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60036) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: insert into test select number, 1, 'str_' || toString(number) from numbers(50000, 100000)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:27.124642 [ 19199 ] {f04b293d-10b7-4ca6-866b-aa1e17abb517} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 3 and result: 1). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000b98536d 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>>*) @ 0x00000000332642ef 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9a063 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:27.487807 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:27.911726 [ 19199 ] {50a4d6c5-3211-4f4d-a845-54f1f66c2e01} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60050) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:16:27.914530 [ 19199 ] {50a4d6c5-3211-4f4d-a845-54f1f66c2e01} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:16:28.506248 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:28.731922 [ 3830 ] {c7e67dc4-c5bb-45f5-ae8d-d8bc262452b4} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'sum' in scope SELECT count(), sum FROM test GROUP BY sum ORDER BY sum ASC, count() ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:60064) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: select count(), sum from test group by sum order by sum, count()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:16:28.734550 [ 3830 ] {c7e67dc4-c5bb-45f5-ae8d-d8bc262452b4} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'sum' in scope SELECT count(), sum FROM test GROUP BY sum ORDER BY sum ASC, count() 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:16:29.655631 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:30.788727 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:30.818753 [ 3830 ] {ddf36204-0071-40f7-bf58-7e1d121d2ad8} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47648) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: select count(), dynamicType(d) from test group by dynamicType(d) order by count(), dynamicType(d)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:16:30.821497 [ 3830 ] {ddf36204-0071-40f7-bf58-7e1d121d2ad8} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'd' in scope SELECT count(), dynamicType(d) FROM test GROUP BY dynamicType(d) ORDER BY count() ASC, dynamicType(d) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003348d655 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 22. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 26. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 27. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:16:31.567540 [ 19199 ] {e076d6a5-04cf-4d90-8ae7-65b17baef24f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'sum' in scope SELECT count(), sum FROM test GROUP BY sum ORDER BY sum ASC, count() ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47658) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: select count(), sum from test group by sum order by sum, count()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:16:31.569625 [ 19199 ] {e076d6a5-04cf-4d90-8ae7-65b17baef24f} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'sum' in scope SELECT count(), sum FROM test GROUP BY sum ORDER BY sum ASC, count() 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:16:32.116374 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:33.155708 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:34.212576 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:35.337528 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:36.486012 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:37.600126 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:38.684878 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:39.851775 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:40.906725 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:41.980865 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:42.715964 [ 3830 ] {6d6048f4-d044-4d06-9003-3ce7823f2982} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:40904) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: optimize table test 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f49a3 21. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30a645 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bc951 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:16:42.718215 [ 3830 ] {6d6048f4-d044-4d06-9003-3ce7823f2982} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000003a2f49a3 21. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000003a30a645 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterOptimizeQuery::execute() @ 0x00000000359bc951 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 30. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 31. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 2025.03.31 19:16:43.114998 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:44.198149 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:45.338687 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:45.858331 [ 15299 ] {07d505ea-5f49-46d6-95e1-9704674f630c} executeQuery: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:41008) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: CREATE TABLE test (`id` UInt64, `sum` UInt64, `d` Dynamic) ENGINE = SummingMergeTree(sum) ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, index_granularity = 8128, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 87616464, compact_parts_max_bytes_to_buffer = 365409209, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 28292734, merge_max_block_size = 8128, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, min_merge_bytes_to_use_direct_io = 6095395931, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 80308, primary_key_compress_block_size = 71121), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:45.860649 [ 15299 ] {07d505ea-5f49-46d6-95e1-9704674f630c} TCPHandler: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:16:46.396273 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:47.512100 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:48.551312 [ 2854 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:49.648225 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:50.755403 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:51.796463 [ 19260 ] {05695acd-3957-4442-a8a6-34028aac5955} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52594) (comment: 03039_dynamic_summing_merge_tree.sh) (in query: select count(), sum from test group by sum order by sum, count()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:16:51.813433 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:51.872401 [ 19260 ] {05695acd-3957-4442-a8a6-34028aac5955} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:16:52.856239 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:53.669737 [ 15299 ] {c9ac0c6a-87b0-4322-bad4-9360c8045146} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50692) (comment: 01414_mutations_and_errors_zookeeper.sh) (in query: DROP DATABASE IF EXISTS test_gsziu8cx ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003487a445 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034925974 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003493136d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 12. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 2025.03.31 19:16:53.672505 [ 15299 ] {c9ac0c6a-87b0-4322-bad4-9360c8045146} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a)) does not support transactions. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000003487a445 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000034925974 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x000000003493136d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 12. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 13. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 18. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 19. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 20. ? @ 0x00007f038ce47ac3 21. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:16:53.946397 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:55.075387 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:55.453569 [ 3325 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:16:56.107259 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:56.454264 [ 3298 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:16:57.270391 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:57.454951 [ 3284 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:16:58.434000 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:58.455638 [ 3279 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:16:58.455659 [ 19260 ] {afafb38e-f8f2-40b8-8b56-8ba9f6452480} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52720) (comment: 02421_explain_subquery.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:58.456928 [ 19260 ] {afafb38e-f8f2-40b8-8b56-8ba9f6452480} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./build_docker/./src/Access/SettingsConstraints.cpp:182: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000315945bb 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x00000000337453f2 8. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:0: DB::InterpreterSetQuery::execute() @ 0x0000000034e64174 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:16:59.456161 [ 3256 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:16:59.465673 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:00.456834 [ 3238 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:00.579473 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:01.457522 [ 3222 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:01.638251 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:02.458312 [ 3217 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:02.735810 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:03.459063 [ 3379 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:03.840654 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:04.459922 [ 3518 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:04.889646 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:05.460729 [ 3182 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:06.109040 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:06.461509 [ 3175 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:07.422092 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:07.462415 [ 3154 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:08.463125 [ 3135 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:08.508843 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:09.463979 [ 3120 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:09.579807 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:10.464729 [ 3086 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:10.778793 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:11.465393 [ 3095 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:11.888027 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:12.466282 [ 3069 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:12.947351 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:13.467110 [ 3058 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:13.788149 [ 3056 ] {} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000339b83d8 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000339b942e 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000339da35f 10. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 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*) @ 0x00000000319a464f 13. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 15. ? @ 0x00007f038ce47ac3 16. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:13.806637 [ 19142 ] {de6c5c0a-e909-46d4-b93e-4e750454ab73} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33780) (comment: 03036_join_filter_push_down_equivalent_sets.sql) (in query: DROP DATABASE IF EXISTS test_15gu2eab ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:17:13.809922 [ 19142 ] {de6c5c0a-e909-46d4-b93e-4e750454ab73} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:14.024541 [ 19260 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:14.468043 [ 3040 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:15.120182 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:15.468895 [ 3023 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:15.686696 [ 12293 ] {953280a5-e373-4da8-bfd6-b7f11f430ab7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42226) (comment: 02125_constant_if_condition_and_not_existing_column.sql) (in query: DROP DATABASE IF EXISTS test_mm7df7n9 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:17:15.689325 [ 12293 ] {953280a5-e373-4da8-bfd6-b7f11f430ab7} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:16.431513 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:16.469670 [ 3495 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:17.470402 [ 3486 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:17.645651 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:18.471217 [ 3469 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:18.852375 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:19.472048 [ 3456 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:19.967371 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:20.472831 [ 3428 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:21.138244 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:21.473585 [ 3426 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:21.948161 [ 15299 ] {3d2065c6-b19a-410e-83c1-5a7402a94f80} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.25 MiB (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:52728) (comment: 01300_group_by_other_keys.sql) (in query: SELECT round(avg(log(2) * number), 6) AS k FROM numbers(10000000) GROUP BY (number % 2) % 3, number % 2 ORDER BY k;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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*&&, char const*&&, String&&, long&, String&&) @ 0x0000000020096687 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094fb3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000001ff77485 7. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000033b439b1 8. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5a6d6 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b75ea94 10. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b752814 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:17:21.953166 [ 15299 ] {3d2065c6-b19a-410e-83c1-5a7402a94f80} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.25 MiB (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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*&&, char const*&&, String&&, long&, String&&) @ 0x0000000020096687 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020094fb3 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x0000000020093e52 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:85: CurrentMemoryTracker::check() @ 0x000000001ff77485 7. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000033b439b1 8. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x0000000033b5a6d6 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000003b75ea94 10. ./src/Common/CollectionOfDerived.h:28: DB::AggregatingTransform::work() @ 0x000000003b752814 11. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 17. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:17:22.027907 [ 3609 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f7684ad4-5a51-47e0-b9af-e4cdeab38f3a::202503_141_151_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:22.334532 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:22.474383 [ 3403 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:23.475136 [ 3385 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:23.478269 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:24.475900 [ 3331 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:24.583348 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:25.476681 [ 3295 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:25.702070 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:26.426397 [ 12294 ] {69cce820-b388-4cb2-9fb7-7e4a24b996e6} 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.10457.altinitytest (altinity build)) (from [::1]:42314) (comment: 01267_alter_default_key_columns_zookeeper_long.sql) (in query: SYSTEM RESTART REPLICA test_alter_r2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x00000000386d761c 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2bf3de 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aed93 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::tryRestartReplica(DB::StorageID const&, std::shared_ptr) @ 0x000000003598898f 14. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:902: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x000000003597e949 15. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:703: DB::InterpreterSystemQuery::execute() @ 0x000000003594fb3d 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:17:26.428915 [ 12294 ] {69cce820-b388-4cb2-9fb7-7e4a24b996e6} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x00000000386d761c 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:0: std::shared_ptr std::allocate_shared[abi:v15007], String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, DB::RenamingRestrictions&, bool&, void>(std::allocator const&, String&, String&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, DB::RenamingRestrictions&, bool&) @ 0x000000003a2bf3de 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aed93 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:0: DB::InterpreterSystemQuery::tryRestartReplica(DB::StorageID const&, std::shared_ptr) @ 0x000000003598898f 14. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:902: DB::InterpreterSystemQuery::restartReplica(DB::StorageID const&, std::shared_ptr) @ 0x000000003597e949 15. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:703: DB::InterpreterSystemQuery::execute() @ 0x000000003594fb3d 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:17:26.477386 [ 3285 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:26.767724 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:27.478141 [ 3269 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:27.888128 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:28.478939 [ 3310 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:29.044288 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:29.479626 [ 3239 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:30.106409 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:30.480301 [ 3214 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:31.154250 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:31.480980 [ 3517 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:32.222671 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:32.481619 [ 3192 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:32.592105 [ 12294 ] {d7f6cf50-48c0-4a07-94f3-0130f4efcf85} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37164) (comment: 02916_addcolumn_nested.sql) (in query: DROP DATABASE IF EXISTS test_kc3hjk4y ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:17:32.594704 [ 12294 ] {d7f6cf50-48c0-4a07-94f3-0130f4efcf85} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:32.680251 [ 12293 ] {156e95c8-8471-4163-a848-07ad86f86684} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37180) (comment: 02916_addcolumn_nested.sql) (in query: DROP DATABASE IF EXISTS test_kc3hjk4y ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:17:32.682818 [ 12293 ] {156e95c8-8471-4163-a848-07ad86f86684} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:33.273242 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:33.482353 [ 3181 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:34.306693 [ 19288 ] {536b76bf-c6fe-4272-b788-4bf7298412d6} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(257)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (ILLEGAL_COLUMN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46982) (comment: 02426_create_suspicious_fixed_string.sql) (in query: CREATE TABLE suspicious_fixed_string (`id` UInt64, `s` FixedString(257)) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 3735, min_bytes_for_wide_part = 745771091, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 2, min_bytes_for_full_part_storage = 467358950, compact_parts_max_bytes_to_buffer = 117658511, compact_parts_max_granules_to_buffer = 49, compact_parts_merge_max_bytes_to_prefetch_part = 27895368, merge_max_block_size = 2993, old_parts_lifetime = 470., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 52, min_merge_bytes_to_use_direct_io = 9737960828, index_granularity_bytes = 19598825, concurrent_part_removal_threshold = 73, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 88459, primary_key_compress_block_size = 38568), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x000000003599d2cd 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:73: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x00000000359991df 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599617b 6. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000348ac6fd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a38c6 8. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:17:34.310800 [ 19288 ] {536b76bf-c6fe-4272-b788-4bf7298412d6} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(257)' because fixed string with size > 256 is suspicious. Set setting allow_suspicious_fixed_string_types = 1 in order to allow it. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, int&&) @ 0x000000003599d2cd 4. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:73: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x00000000359991df 5. ./build_docker/./src/Interpreters/parseColumnsListForTableFunction.cpp:153: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x000000003599617b 6. ./contrib/llvm-project/libcxx/include/list:400: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000348ac6fd 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000348a38c6 8. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:17:34.376402 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:34.483123 [ 3161 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:35.483906 [ 3133 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:35.607006 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:36.517242 [ 3115 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:36.681932 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:37.518211 [ 3097 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:37.821871 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:38.519041 [ 3076 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:38.873436 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:39.519693 [ 3050 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:39.927076 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:40.520411 [ 3033 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:40.976236 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:41.521099 [ 3018 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:42.142864 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:42.415185 [ 3604 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8c2d7c1f-a424-404f-ac7d-e150141efc8a::202503_1_132_28}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:42.521900 [ 3493 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:43.238816 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:43.522625 [ 3479 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:44.269683 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:44.523308 [ 3453 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:45.310699 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:45.523912 [ 3439 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:46.499600 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:46.524596 [ 3418 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:47.525276 [ 3412 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:47.579146 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:48.526274 [ 3380 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:48.679654 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:49.527065 [ 3358 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:49.716942 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:50.293976 [ 19288 ] {e1ad1496-6236-4b0f-9943-3fa4a51d32f5} executeQuery: Code: 69. DB::Exception: A call to function range would produce 18446744073709550590 array elements, which is greater than the allowed maximum of 500000000: In scope SELECT range(1025, 18446744073709551615, 1). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:54350) (comment: 01408_range_overflow.sql) (in query: SELECT range(1025, 18446744073709551615, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. COW::immutable_ptr DB::FunctionRange::executeGeneric(DB::IColumn const*, DB::IColumn const*, DB::IColumn const*, unsigned long) const @ 0x000000001fed2f48 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe91f70 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 2025.03.31 19:17:50.295476 [ 19288 ] {e1ad1496-6236-4b0f-9943-3fa4a51d32f5} TCPHandler: Code: 69. DB::Exception: A call to function range would produce 18446744073709550590 array elements, which is greater than the allowed maximum of 500000000: In scope SELECT range(1025, 18446744073709551615, 1). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x0000000008618137 4. COW::immutable_ptr DB::FunctionRange::executeGeneric(DB::IColumn const*, DB::IColumn const*, DB::IColumn const*, unsigned long) const @ 0x000000001fed2f48 5. DB::FunctionRange::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001fe91f70 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 14. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 29. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 2025.03.31 19:17:50.527856 [ 3354 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:50.769506 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:51.528518 [ 3334 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:51.892446 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:52.455764 [ 19199 ] {0408bf5f-d4f8-45cc-9b75-1820f9e8c58d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42794) (comment: 01513_defaults_on_defaults_no_column.sql) (in query: SELECT * from defaults_on_defaults where ArrLen = 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:17:52.460142 [ 19199 ] {0408bf5f-d4f8-45cc-9b75-1820f9e8c58d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:17:52.529178 [ 3299 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:52.946474 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:53.530008 [ 3275 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:53.720677 [ 5377 ] {} test_1.test_smt (c8273e8e-d75a-4fb9-9cdc-98cce76b19bb): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.03.31 19:17:53.721265 [ 5377 ] {} DatabaseCatalog: Cannot drop table test_1.test_smt (c8273e8e-d75a-4fb9-9cdc-98cce76b19bb). 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 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>*) @ 0x00000000397276a1 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>*) @ 0x0000000039720472 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2997: DB::MergeTreeData::dropAllData() @ 0x0000000039736baa 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2cda53 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339b9fe2 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339daaa3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303ec68c 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()() @ 0x00000000303ec46d 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b123d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303eeb6e 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:54.014867 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:54.530704 [ 3252 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:55.058621 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:55.531336 [ 3239 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:56.133986 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:56.532144 [ 3223 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:57.183543 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:57.532833 [ 3196 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:58.211703 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:58.533623 [ 3509 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:17:58.834226 [ 19199 ] {14f5eb68-035a-4fa7-bd9d-ec1a15872a27} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42810) (comment: 01630_simple_aggregate_function_in_summing_merge_tree.sql) (in query: CREATE TABLE simple_agf_summing_mt (`a` Int64, `grp_aggreg` AggregateFunction(groupUniqArrayArray, Array(UInt64)), `grp_simple` SimpleAggregateFunction(groupUniqArrayArray, Array(UInt64))) ENGINE = SummingMergeTree ORDER BY a SETTINGS index_granularity = 53488, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 479521383, compact_parts_max_bytes_to_buffer = 215071132, compact_parts_max_granules_to_buffer = 196, compact_parts_merge_max_bytes_to_prefetch_part = 12304711, merge_max_block_size = 4737, old_parts_lifetime = 71., 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 = 10737418240, index_granularity_bytes = 7324710, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 71357, primary_key_compress_block_size = 11024), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 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>) @ 0x000000003a2c1d8a 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>&&) @ 0x000000003a2bfe8f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:17:58.836805 [ 19199 ] {14f5eb68-035a-4fa7-bd9d-ec1a15872a27} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 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>) @ 0x000000003a2c1d8a 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>&&) @ 0x000000003a2bfe8f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:17:59.404629 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:17:59.534515 [ 3179 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:00.467548 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:00.535096 [ 3164 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:01.535814 [ 3146 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:01.619488 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:02.536454 [ 3118 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:02.699120 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:03.537190 [ 3100 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:03.882436 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:04.538045 [ 3081 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:04.954389 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:05.538752 [ 3059 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:06.123781 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:06.539355 [ 3050 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:07.213696 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:07.539977 [ 3033 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:08.275021 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:08.540812 [ 3014 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:09.337989 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:09.541737 [ 3491 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:10.373678 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:10.542612 [ 3478 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:11.497585 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:11.543303 [ 3450 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:12.544094 [ 3430 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:12.567136 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:13.544880 [ 3420 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:13.583949 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:14.545619 [ 3393 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:14.617335 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:15.539603 [ 3599 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7b93f28a-4c9d-4e36-add9-0e92a5ccdc5c::202503_1_186_37}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:15.546448 [ 3348 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:15.776551 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:16.547319 [ 3323 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:16.821589 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:17.543801 [ 19199 ] {17ab26a7-3a2f-4de1-88aa-9414e7c84237} 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.10457.altinitytest (altinity build)) (from [::1]:45746) (comment: 00705_drop_create_merge_tree.sh) (in query: CREATE TABLE IF NOT EXISTS `table` (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 52636, min_bytes_for_wide_part = 1012836800, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 12, min_bytes_for_full_part_storage = 473456989, compact_parts_max_bytes_to_buffer = 303625864, compact_parts_max_granules_to_buffer = 79, compact_parts_merge_max_bytes_to_prefetch_part = 21708454, merge_max_block_size = 17579, old_parts_lifetime = 181., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 5538838931, index_granularity_bytes = 1225414, concurrent_part_removal_threshold = 55, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 18212, primary_key_compress_block_size = 24363), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 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>) @ 0x000000003a2c1d8a 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>&&) @ 0x000000003a2bfe8f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:18:17.547238 [ 19199 ] {17ab26a7-3a2f-4de1-88aa-9414e7c84237} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x00000000396eab4f 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>) @ 0x000000003a2c1d8a 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>&&) @ 0x000000003a2bfe8f 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000003a2aeea3 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000030c742ba 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 @ 0x00000000382ef4c6 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d03ec 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 15. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 23. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 24. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 25. ? @ 0x00007f038ce47ac3 26. ? @ 0x00007f038ced9850 2025.03.31 19:18:17.548070 [ 3301 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:17.885924 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:18.548823 [ 3280 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:18.945661 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:19.549538 [ 3265 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:20.070825 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:20.550280 [ 3247 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:21.214825 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:21.551025 [ 3235 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:22.403099 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:22.551716 [ 3221 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:23.552411 [ 3199 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:23.580502 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:24.553179 [ 3197 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:24.861390 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:25.554103 [ 3177 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:26.020230 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:26.554978 [ 3159 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:27.074186 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:27.555799 [ 3145 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:28.228083 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:28.556599 [ 3128 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:29.284685 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:29.557418 [ 3116 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:30.391500 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:30.558329 [ 3089 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:31.502115 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:31.558957 [ 3077 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:32.548386 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:32.559559 [ 3066 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:33.560337 [ 3037 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:33.575238 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:34.029666 [ 12293 ] {758d0487-434f-402d-83b0-1a63af8bdf37} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:37208) (comment: 02426_create_suspicious_fixed_string.sql) (in query: DROP DATABASE IF EXISTS test_kglk0gsa ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:18:34.032481 [ 12293 ] {758d0487-434f-402d-83b0-1a63af8bdf37} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:34.122584 [ 15299 ] {9447aec7-efa2-4af4-9da7-3a5b547e5744} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:34210) (comment: 02426_create_suspicious_fixed_string.sql) (in query: DROP DATABASE IF EXISTS test_kglk0gsa ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:18:34.125173 [ 15299 ] {9447aec7-efa2-4af4-9da7-3a5b547e5744} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:34.142425 [ 12294 ] {653b3b59-ecfa-4213-8fe2-0faae97188eb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:34224) (comment: 02426_create_suspicious_fixed_string.sql) (in query: DROP DATABASE IF EXISTS test_kglk0gsa ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:18:34.144774 [ 12294 ] {653b3b59-ecfa-4213-8fe2-0faae97188eb} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:34.162896 [ 15299 ] {8cb3b9e5-6d02-4360-b6d0-58476c10bfe3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:34226) (comment: 02426_create_suspicious_fixed_string.sql) (in query: DROP DATABASE IF EXISTS test_kglk0gsa ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:18:34.165393 [ 15299 ] {8cb3b9e5-6d02-4360-b6d0-58476c10bfe3} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:34.561054 [ 3022 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:34.642954 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:35.562035 [ 3496 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:35.686314 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:36.562690 [ 3480 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:36.714196 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:37.563341 [ 3463 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:37.792775 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:38.564046 [ 3436 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:38.894789 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:39.564766 [ 3415 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:39.966919 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:40.565561 [ 3412 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:41.024399 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:41.566523 [ 3385 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:41.582673 [ 15299 ] {82087ef7-b6c0-42e3-86a2-ccf4d2f906ec} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33864) (comment: 02306_part_types_profile_events.sql) (in query: DROP DATABASE IF EXISTS test_1k3f6e8i ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:18:41.584861 [ 15299 ] {82087ef7-b6c0-42e3-86a2-ccf4d2f906ec} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:42.127476 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:42.567291 [ 3361 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:43.278099 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:43.568068 [ 3378 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:44.459818 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:44.568705 [ 3325 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:45.492035 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:45.569616 [ 3292 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:46.527695 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:46.570551 [ 3275 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:47.571418 [ 3262 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:47.646528 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:48.572102 [ 3247 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:48.672961 [ 19199 ] {a68cf1fc-a69a-4e83-8fbb-4190e8793292} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33802) (comment: 02154_dictionary_get_http_json.sh) (in query: DROP DICTIONARY 02154_test_dictionary), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:18:48.676204 [ 19199 ] {a68cf1fc-a69a-4e83-8fbb-4190e8793292} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:18:48.719000 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:49.572817 [ 3235 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:49.914155 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:50.573621 [ 3220 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:50.988141 [ 3607 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fce196b8-b32c-4319-8cdf-3d340eb025b8::202503_219_322_11}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009656d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009133f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff77dff 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x0000000020113c7f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3a3572 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a0374 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:51.057996 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:51.486091 [ 19199 ] {5c8d00a7-7151-4253-a989-2539e7278764} executeQuery: Code: 180. DB::Exception: There is no settings profile `s2_01294` in user directories. (THERE_IS_NO_PROFILE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59604) (comment: 01294_create_settings_profile.sql) (in query: SHOW CREATE SETTINGS PROFILE s2_01294;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f3b30 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f3900 5. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x0000000036ec5991 6. ./contrib/abseil-cpp/absl/container/internal/compressed_tuple.h:90: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x0000000036ec2995 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x0000000036ec07a1 8. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x0000000036ec0664 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:51.487513 [ 19199 ] {5c8d00a7-7151-4253-a989-2539e7278764} TCPHandler: Code: 180. DB::Exception: There is no settings profile `s2_01294` in user directories. (THERE_IS_NO_PROFILE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IAccessStorage::throwNotFound(DB::AccessEntityType, String const&) const @ 0x00000000313f3b30 4. ./build_docker/./src/Access/IAccessStorage.cpp:0: DB::IAccessStorage::getID(DB::AccessEntityType, String const&) const @ 0x00000000313f3900 5. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::getEntities() const @ 0x0000000036ec5991 6. ./contrib/abseil-cpp/absl/container/internal/compressed_tuple.h:90: DB::InterpreterShowCreateAccessEntityQuery::getCreateQueries() const @ 0x0000000036ec2995 7. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::executeImpl() @ 0x0000000036ec07a1 8. ./build_docker/./src/Interpreters/Access/InterpreterShowCreateAccessEntityQuery.cpp:0: DB::InterpreterShowCreateAccessEntityQuery::execute() @ 0x0000000036ec0664 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:51.574536 [ 3203 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:52.285941 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:52.575199 [ 3518 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:53.413001 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:53.575825 [ 3169 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.498815 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:54.515392 [ 12294 ] {bef3b008-a149-4108-9847-0c0bab3da3ed} executeQuery: Code: 341. DB::Exception: Mutation mutation_12.txt was killed. (UNFINISHED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59640) (comment: 02932_apply_deleted_mask.sql) (in query: ALTER TABLE t_materialize_delete APPLY DELETED MASK;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfbd92 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:54.515609 [ 3607 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::3_4_4_0_12} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.515847 [ 3604 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::7_8_8_0_12} MutatePlainMergeTreeTask: Code: 236. DB::Exception: Cancelled mutating parts. (ABORTED) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.517517 [ 12294 ] {bef3b008-a149-4108-9847-0c0bab3da3ed} TCPHandler: Code: 341. DB::Exception: Mutation mutation_12.txt was killed. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:22: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000039bfbd92 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000003a2da099 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000003a2dd535 7. ./contrib/llvm-project/libcxx/include/vector:553: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000034854f93 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000003484c5b0 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:54.534528 [ 3596 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::1_2_2_0_12} MutatePlainMergeTreeTask: Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.536706 [ 3596 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::1_2_2_0_12} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::checkIsNotCancelled() const @ 0x0000000034f45b18 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:137: DB::MergeTreeTransaction::addNewPart(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034f46672 6. ./contrib/llvm-project/libcxx/include/vector:1463: DB::MergeTreeTransaction::addNewPartAndRemoveCovered(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::MergeTreeTransaction*) @ 0x0000000034f47bf8 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::Transaction::commit(DB::DataPartsLock*) @ 0x000000003981d218 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aaedc 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.541351 [ 3600 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::4_5_5_0_12} MutatePlainMergeTreeTask: Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.542979 [ 3600 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::4_5_5_0_12} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::checkIsNotCancelled() const @ 0x0000000034f45b18 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:137: DB::MergeTreeTransaction::addNewPart(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034f46672 6. ./contrib/llvm-project/libcxx/include/vector:1463: DB::MergeTreeTransaction::addNewPartAndRemoveCovered(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::MergeTreeTransaction*) @ 0x0000000034f47bf8 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::Transaction::commit(DB::DataPartsLock*) @ 0x000000003981d218 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aaedc 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.556129 [ 3601 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::6_7_7_0_12} MutatePlainMergeTreeTask: Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.557444 [ 3601 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::6_7_7_0_12} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::checkIsNotCancelled() const @ 0x0000000034f45b18 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:137: DB::MergeTreeTransaction::addNewPart(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034f46672 6. ./contrib/llvm-project/libcxx/include/vector:1463: DB::MergeTreeTransaction::addNewPartAndRemoveCovered(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::MergeTreeTransaction*) @ 0x0000000034f47bf8 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::Transaction::commit(DB::DataPartsLock*) @ 0x000000003981d218 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aaedc 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.560564 [ 3598 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::5_6_6_0_12} MutatePlainMergeTreeTask: Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.561909 [ 3598 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::5_6_6_0_12} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::checkIsNotCancelled() const @ 0x0000000034f45b18 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:137: DB::MergeTreeTransaction::addNewPart(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034f46672 6. ./contrib/llvm-project/libcxx/include/vector:1463: DB::MergeTreeTransaction::addNewPartAndRemoveCovered(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::MergeTreeTransaction*) @ 0x0000000034f47bf8 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::Transaction::commit(DB::DataPartsLock*) @ 0x000000003981d218 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aaedc 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.576502 [ 3125 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.619275 [ 3605 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::0_1_1_0_12} MutatePlainMergeTreeTask: Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.620597 [ 3605 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::0_1_1_0_12} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::checkIsNotCancelled() const @ 0x0000000034f45b18 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:137: DB::MergeTreeTransaction::addNewPart(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034f46672 6. ./contrib/llvm-project/libcxx/include/vector:1463: DB::MergeTreeTransaction::addNewPartAndRemoveCovered(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::MergeTreeTransaction*) @ 0x0000000034f47bf8 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::Transaction::commit(DB::DataPartsLock*) @ 0x000000003981d218 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aaedc 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.626495 [ 3603 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::2_3_3_0_12} MutatePlainMergeTreeTask: Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION) (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.627722 [ 3603 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::2_3_3_0_12} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 649. DB::Exception: Transaction was cancelled. (INVALID_TRANSACTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:0: DB::MergeTreeTransaction::checkIsNotCancelled() const @ 0x0000000034f45b18 5. ./build_docker/./src/Interpreters/MergeTreeTransaction.cpp:137: DB::MergeTreeTransaction::addNewPart(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000034f46672 6. ./contrib/llvm-project/libcxx/include/vector:1463: DB::MergeTreeTransaction::addNewPartAndRemoveCovered(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::MergeTreeTransaction*) @ 0x0000000034f47bf8 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeData::Transaction::commit(DB::DataPartsLock*) @ 0x000000003981d218 8. ./contrib/llvm-project/libcxx/include/vector:438: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aaedc 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.638114 [ 3830 ] {52712425-08e8-4a52-bdaa-21a1a0306a0d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38430) (comment: 02932_apply_deleted_mask.sql) (in query: DROP DATABASE IF EXISTS test_16i6i8c7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:18:54.640677 [ 3830 ] {52712425-08e8-4a52-bdaa-21a1a0306a0d} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.658727 [ 12294 ] {7a1fee94-fd2d-4553-a5ef-426545b8ea8f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38436) (comment: 02932_apply_deleted_mask.sql) (in query: DROP DATABASE IF EXISTS test_16i6i8c7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:18:54.661217 [ 12294 ] {7a1fee94-fd2d-4553-a5ef-426545b8ea8f} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:54.715004 [ 19199 ] {5dd35d0e-82aa-4abc-8ea8-5832501a4c29} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38450) (comment: 02932_apply_deleted_mask.sql) (in query: DROP DATABASE IF EXISTS test_16i6i8c7 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:18:54.717456 [ 19199 ] {5dd35d0e-82aa-4abc-8ea8-5832501a4c29} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:55.043358 [ 3604 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::7_8_8_0_12} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 236. DB::Exception: Cancelled mutating parts. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1049: DB::MutationContext::checkOperationIsNotCanceled() const @ 0x0000000039ea360d 5. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e634cf 6. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 7. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aa57c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:55.577251 [ 3107 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:55.615935 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:55.768790 [ 3607 ] {bb3a967e-350a-4702-9e6b-a23a47af1795::3_4_4_0_12} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x0000000039ce71b2 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&) @ 0x0000000039ce966a 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 @ 0x0000000032630982 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x000000003263138d 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x0000000039ce0b44 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) @ 0x0000000039ce0469 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&) @ 0x000000003999ab28 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 @ 0x000000003998fbb4 17. ./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) @ 0x0000000039cf5524 18. ./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&) @ 0x0000000039cffcb9 19. ./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) @ 0x0000000039cfbf26 20. ./contrib/llvm-project/libcxx/include/optional:260: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000039d03d22 21. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:0: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000003be03743 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:296: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000003be71d65 23. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1312: DB::MutationsInterpreter::addStreamsForLaterStages(std::vector> const&, DB::QueryPlan&) const @ 0x0000000034f91bf1 24. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::execute() @ 0x0000000034f9c58b 25. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::prepare() @ 0x0000000039e68dd2 26. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:2054: DB::MutateTask::execute() @ 0x0000000039e62f96 27. ./build_docker/./src/Storages/MergeTree/MutatePlainMergeTreeTask.cpp:0: DB::MutatePlainMergeTreeTask::executeStep() @ 0x000000003a3aa57c 28. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 29. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:55.774165 [ 5926 ] {} test_16i6i8c7.t_materialize_delete (bb3a967e-350a-4702-9e6b-a23a47af1795): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.03.31 19:18:55.775466 [ 5926 ] {} DatabaseCatalog: Cannot drop table test_16i6i8c7.t_materialize_delete (bb3a967e-350a-4702-9e6b-a23a47af1795). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 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>*) @ 0x00000000397276a1 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>*) @ 0x0000000039720472 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2997: DB::MergeTreeData::dropAllData() @ 0x0000000039736baa 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:317: DB::StorageMergeTree::drop() @ 0x000000003a2cda53 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000339b9fe2 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000339daaa3 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000303ec68c 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()() @ 0x00000000303ec46d 15. ./contrib/llvm-project/libcxx/include/future:2069: std::packaged_task::operator()() @ 0x00000000214b123d 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000303eeb6e 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 18. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 20. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 22. ? @ 0x00007f038ce47ac3 23. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:56.578168 [ 3079 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:56.671686 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:57.023723 [ 19199 ] {a43f4231-0556-4e9b-b315-0d8c7f79e1c2} executeQuery: Code: 36. DB::Exception: All numbers in both samples are identical: While executing ConvertingAggregatedToChunksTransform. (BAD_ARGUMENTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59666) (comment: 01560_mann_whitney.sql) (in query: WITH mannWhitneyUTest('two-sided')(1, right) AS pair SELECT roundBankers(pair.1, 16) AS t_stat, roundBankers(pair.2, 16) AS p_value FROM mann_whitney_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./src/AggregateFunctions/StatCommon.h:51: DB::(anonymous namespace)::AggregateFunctionMannWhitney::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x000000002f614174 5. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x0000000033d9fcf0 6. ./build_docker/./src/Interpreters/Aggregator.cpp:2144: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x0000000033b6c894 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:470: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x000000003b76fbef 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::ConvertingAggregatedToChunksTransform::work() @ 0x000000003b765c1d 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:18:57.026602 [ 19199 ] {a43f4231-0556-4e9b-b315-0d8c7f79e1c2} TCPHandler: Code: 36. DB::Exception: All numbers in both samples are identical: While executing ConvertingAggregatedToChunksTransform. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./src/AggregateFunctions/StatCommon.h:51: DB::(anonymous namespace)::AggregateFunctionMannWhitney::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x000000002f614174 5. ./build_docker/./src/Interpreters/Aggregator.cpp:0: void DB::Aggregator::insertAggregatesIntoColumns(char*&, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::Arena*) const @ 0x0000000033d9fcf0 6. ./build_docker/./src/Interpreters/Aggregator.cpp:2144: DB::Aggregator::prepareBlockAndFillWithoutKey(DB::AggregatedDataVariants&, bool, bool) const @ 0x0000000033b6c894 7. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:470: DB::ConvertingAggregatedToChunksTransform::initialize() @ 0x000000003b76fbef 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::ConvertingAggregatedToChunksTransform::work() @ 0x000000003b765c1d 9. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:18:57.578799 [ 3080 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:57.711844 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:58.579549 [ 3051 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:58.839919 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:18:59.580152 [ 3022 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:18:59.880467 [ 3830 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:00.580920 [ 3496 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:01.016124 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:01.581896 [ 3466 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:02.312891 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:02.582595 [ 3463 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:03.436809 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:03.583426 [ 3449 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:04.391630 [ 3608 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fce196b8-b32c-4319-8cdf-3d340eb025b8::202503_323_328_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009656d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009133f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff77dff 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x0000000020113c7f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3a3572 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a0374 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:04.539145 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:04.584390 [ 3417 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:04.696574 [ 3600 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0f4221a3-ac36-4096-997d-800f51b611e3::202503_1_30_6}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:05.585252 [ 3424 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:05.607847 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:06.586131 [ 3377 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:06.641009 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:06.878356 [ 3830 ] {2f76cc74-e01c-409d-9bea-5f15cd94618c} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 0, should be 1: In scope SELECT isConstant(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58334) (comment: 01118_is_constant.sql) (in query: select isConstant();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b608797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b604685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60580b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b604fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:19:06.879827 [ 3830 ] {2f76cc74-e01c-409d-9bea-5f15cd94618c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 0, should be 1: In scope SELECT isConstant(). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b608797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b604685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60580b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b604fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:19:06.896258 [ 3830 ] {c1e7aa32-21c6-4d2f-8bc2-d6bedfb9d020} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(1, 2). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:58334) (comment: 01118_is_constant.sql) (in query: select isConstant(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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b608797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b604685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60580b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b604fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:19:06.897526 [ 3830 ] {c1e7aa32-21c6-4d2f-8bc2-d6bedfb9d020} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant(1, 2). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000b608797 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000b604685 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b60580b 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b604fd4 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 12. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 24. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 28. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 29. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 30. ? @ 0x00007f038ce47ac3 31. ? @ 0x00007f038ced9850 2025.03.31 19:19:07.586781 [ 3340 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:07.720860 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:08.547854 [ 3830 ] {0c6bd82e-add3-4247-9faa-9b62f1b276f6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51258) (comment: 02502_analyzer_insert_select_crash_fix.sql) (in query: DROP DATABASE IF EXISTS test_macix435 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:19:08.550634 [ 3830 ] {0c6bd82e-add3-4247-9faa-9b62f1b276f6} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:08.567179 [ 12293 ] {da19481f-655e-49d4-a978-2b509de29055} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:51260) (comment: 02502_analyzer_insert_select_crash_fix.sql) (in query: DROP DATABASE IF EXISTS test_macix435 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:19:08.569574 [ 12293 ] {da19481f-655e-49d4-a978-2b509de29055} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:08.587543 [ 3323 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:08.843585 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:08.933531 [ 19199 ] {4e36ce61-1c76-4af6-baea-25be7c031f46} 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.10457.altinitytest (altinity build)) (from [::1]:58390) (comment: 02494_query_cache_min_query_runs.sql) (in query: SELECT COUNT(*) FROM system.query_cache;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:19:08.972836 [ 19199 ] {4e36ce61-1c76-4af6-baea-25be7c031f46} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:19:09.588292 [ 3307 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:09.782545 [ 12293 ] {a8c82cf8-a011-47d4-9001-0e72587f540c} 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.10457.altinitytest (altinity build)) (from [::1]:59280) (comment: 02483_check_virtuals_shile_using_structure_from_insertion_table.sql) (in query: insert into function file(02483_data.LineAsString) select 'Hello' settings engine_file_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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae5cf59 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:19:09.787987 [ 12293 ] {a8c82cf8-a011-47d4-9001-0e72587f540c} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d70eb 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae5cf59 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 2025.03.31 19:19:10.011029 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:10.588991 [ 3291 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:11.006519 [ 19199 ] {17e0a45d-026a-46ad-a528-2eed9cbeb3a1} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59264) (comment: 02366_direct_dictionary_dict_has.sql) (in query: DROP DICTIONARY test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:19:11.008829 [ 19199 ] {17e0a45d-026a-46ad-a528-2eed9cbeb3a1} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000003492af8b 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:115: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x000000003492345f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:87: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x000000003492095d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:19:11.033430 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:11.144384 [ 3830 ] {459da635-97b6-4089-b556-cac39d37ea83} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:33078) (comment: 02366_direct_dictionary_dict_has.sql) (in query: DROP DATABASE IF EXISTS test_u3es0jc4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:19:11.147201 [ 3830 ] {459da635-97b6-4089-b556-cac39d37ea83} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:11.154684 [ 12293 ] {68393d27-666c-4325-8293-6ece1b1f4e98} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59302) (comment: 02152_dictionary_date32_type.sql) (in query: SELECT * FROM test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:19:11.159466 [ 12293 ] {68393d27-666c-4325-8293-6ece1b1f4e98} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:19:11.590073 [ 3268 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:12.069095 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:12.591037 [ 3249 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:13.132283 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:13.515280 [ 15299 ] {6b6a1c0a-95d4-4e5c-9984-ada40fe328f9} executeQuery: Code: 44. DB::Exception: Cannot insert MessagePack UUID into column with type Int32.: (in file/uri /var/lib/clickhouse/user_files/02422_data.msgpack): While executing MagPackRowInputFormat: While executing File. (ILLEGAL_COLUMN) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59320) (comment: 02422_msgpack_uuid_wrong_column.sql) (in query: select * from file(02422_data.msgpack, auto, 'x Int32');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:338: DB::insertUUID(DB::IColumn&, std::shared_ptr, char const*, unsigned long) @ 0x000000003b27b1fd 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:486: DB::MsgPackVisitor::visit_ext(char const*, unsigned int) @ 0x000000003b27991c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2aebd3 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b2853ea 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b27c108 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b01ef53 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aeb5ab9 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae2c8d3 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831beb7 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae2c8d3 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:19:13.518637 [ 15299 ] {6b6a1c0a-95d4-4e5c-9984-ada40fe328f9} TCPHandler: Code: 44. DB::Exception: Cannot insert MessagePack UUID into column with type Int32.: (in file/uri /var/lib/clickhouse/user_files/02422_data.msgpack): While executing MagPackRowInputFormat: While executing File. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:338: DB::insertUUID(DB::IColumn&, std::shared_ptr, char const*, unsigned long) @ 0x000000003b27b1fd 5. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:486: DB::MsgPackVisitor::visit_ext(char const*, unsigned int) @ 0x000000003b27991c 6. ./contrib/msgpack-c/include/msgpack/v3/parse.hpp:0: msgpack::v3::detail::context>::execute(char const*, unsigned long, unsigned long&) @ 0x000000003b2aebd3 7. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:505: bool DB::MsgPackRowInputFormat::readObject>(msgpack::v3::detail::parse_helper&) @ 0x000000003b2853ea 8. ./build_docker/./src/Processors/Formats/Impl/MsgPackRowInputFormat.cpp:545: DB::MsgPackRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000003b27c108 9. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000003b01ef53 10. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000003aeb5ab9 11. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae2c8d3 12. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 13. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000003ae605c4 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000003aea2852 17. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000003831beb7 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000003ae2c8d3 19. ./contrib/llvm-project/libcxx/include/optional:344: DB::ISource::work() @ 0x000000003ae2bd1e 20. ./contrib/llvm-project/libcxx/include/list:588: DB::ExecutionThreadContext::executeTask() @ 0x000000003ae929ad 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000003ae618e6 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000003ae640f8 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 2025.03.31 19:19:13.569097 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:19:13.591598 [ 3235 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:14.156568 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:14.592381 [ 3220 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:15.252749 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:15.421466 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:19:15.593051 [ 3507 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:16.315374 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:16.593851 [ 3184 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:17.379808 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:17.594590 [ 3169 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:18.466863 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:18.595284 [ 3154 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:19.563630 [ 15299 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:19.595881 [ 3130 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:20.596562 [ 3112 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:20.784720 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:21.597151 [ 3097 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:21.935400 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:22.627369 [ 3068 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:22.985316 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:23.418408 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:19:23.628060 [ 3046 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:24.029557 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:24.628780 [ 3015 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:25.222526 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:25.629506 [ 3494 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:26.323920 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:26.630197 [ 3466 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:27.361089 [ 19260 ] {54aa8c95-f4bb-4118-ad2c-a501468f0b49} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 129.923521288 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42270) (comment: 03094_one_thousand_joins.sql) (in query: -- Bug 33446, marked as 'long' because it still runs around 10 sec SELECT * FROM (SELECT 1 AS x) t1 JOIN (SELECT 1 AS x) t2 ON t1.x = t2.x JOIN (SELECT 1 AS x) t3 ON t1.x = t3.x JOIN (SELECT 1 AS x) t4 ON t1.x = t4.x JOIN (SELECT 1 AS x) t5 ON t1.x = t5.x JOIN (SELECT 1 AS x) t6 ON t1.x = t6.x JOIN (SELECT 1 AS x) t7 ON t1.x = t7.x JOIN (SELECT 1 AS x) t8 ON t1.x = t8.x JOIN (SELECT 1 AS x) t9 ON t1.x = t9.x JOIN (SELECT 1 AS x) t10 ON t1.x = t10.x JOIN (SELECT 1 AS x) t11 ON t1.x = t11.x JOIN (SELECT 1 AS x) t12 ON t1.x = t12.x JOIN (SELECT 1 AS x) t13 ON t1.x = t13.x JOIN (SELECT 1 AS x) t14 ON t1.x = t14.x JOIN (SELECT 1 AS x) t15 ON t1.x = t15.x JOIN (SELECT 1 AS x) t16 ON t1.x = t16.x JOIN (SELECT 1 AS x) t17 ON t1.x = t17.x JOIN (SELECT 1 AS x) t18 ON t1.x = t18.x JOIN (SELECT 1 AS x) t19 ON t1.x = t19.x JOIN (SELECT 1 AS x) t20 ON t1.x = t20.x JOIN (SELECT 1 AS x) t21 ON t1.x = t21.x JOIN (SELECT 1 AS x) t22 ON t1.x = t22.x JOIN (SELECT 1 AS x) t23 ON t1.x = t23.x JOIN (SELECT 1 AS x) t24 ON t1.x = t24.x JOIN (SELECT 1 AS x) t25 ON t1.x = t25.x JOIN (SELECT 1 AS x) t26 ON t1.x = t26.x JOIN (SELECT 1 AS x) t27 ON t1.x = t27.x JOIN (SELECT 1 AS x) t28 ON t1.x = t28.x JOIN (SELECT 1 AS x) t29 ON t1.x = t29.x JOIN (SELECT 1 AS x) t30 ON t1.x = t30.x JOIN (SELECT 1 AS x) t31 ON t1.x = t31.x JOIN (SELECT 1 AS x) t32 ON t1.x = t32.x JOIN (SELECT 1 AS x) t33 ON t1.x = t33.x JOIN (SELECT 1 AS x) t34 ON t1.x = t34.x JOIN (SELECT 1 AS x) t35 ON t1.x = t35.x JOIN (SELECT 1 AS x) t36 ON t1.x = t36.x JOIN (SELECT 1 AS x) t37 ON t1.x = t37.x JOIN (SELECT 1 AS x) t38 ON t1.x = t38.x JOIN (SELECT 1 AS x) t39 ON t1.x = t39.x JOIN (SELECT 1 AS x) t40 ON t1.x = t40.x JOIN (SELECT 1 AS x) t41 ON t1.x = t41.x JOIN (SELECT 1 AS x) t42 ON t1.x = t42.x JOIN (SELECT 1 AS x) t43 ON t1.x = t43.x JOIN (SELECT 1 AS x) t44 ON t1.x = t44.x JOIN (SELECT 1 AS x) t45 ON t1.x = t45.x JOIN (SELECT 1 AS x) t46 ON t1.x = t46.x JOIN (SELECT 1 AS x) t47 ON t1.x = t47.x JOIN (SELECT 1 AS x) t48 ON t1.x = t48.x JOIN (SELECT 1 AS x) t49 ON t1.x = t49.x JOIN (SELECT 1 AS x) t50 ON t1.x = t50.x JOIN (SELECT 1 AS x) t51 ON t1.x = t51.x JOIN (SELECT 1 AS x) t52 ON t1.x = t52.x JOIN (SELECT 1 AS x) t53 ON t1.x = t53.x JOIN (SELECT 1 AS x) t54 ON t1.x = t54.x JOIN (SELECT 1 AS x) t55 ON t1.x = t55.x JOIN (SELECT 1 AS x) t56 ON t1.x = t56.x JOIN (SELECT 1 AS x) t57 ON t1.x = t57.x JOIN (SELECT 1 AS x) t58 ON t1.x = t58.x JOIN (SELECT 1 AS x) t59 ON t1.x = t59.x JOIN (SELECT 1 AS x) t60 ON t1.x = t60.x JOIN (SELECT 1 AS x) t61 ON t1.x = t61.x JOIN (SELECT 1 AS x) t62 ON t1.x = t62.x JOIN (SELECT 1 AS x) t63 ON t1.x = t63.x JOIN (SELECT 1 AS x) t64 ON t1.x = t64.x JOIN (SELECT 1 AS x) t65 ON t1.x = t65.x JOIN (SELECT 1 AS x) t66 ON t1.x = t66.x JOIN (SELECT 1 AS x) t67 ON t1.x = t67.x JOIN (SELECT 1 AS x) t68 ON t1.x = t68.x JOIN (SELECT 1 AS x) t69 ON t1.x = t69.x JOIN (SELECT 1 AS x) t70 ON t1.x = t70.x JOIN (SELECT 1 AS x) t71 ON t1.x = t71.x JOIN (SELECT 1 AS x) t72 ON t1.x = t72.x JOIN (SELECT 1 AS x) t73 ON t1.x = t73.x JOIN (SELECT 1 AS x) t74 ON t1.x = t74.x JOIN (SELECT 1 AS x) t75 ON t1.x = t75.x JOIN (SELECT 1 AS x) t76 ON t1.x = t76.x JOIN (SELECT 1 AS x) t77 ON t1.x = t77.x JOIN (SELECT 1 AS x) t78 ON t1.x = t78.x JOIN (SELECT 1 AS x) t79 ON t1.x = t79.x JOIN (SELECT 1 AS x) t80 ON t1.x = t80.x JOIN (SELECT 1 AS x) t81 ON t1.x = t81.x JOIN (SELECT 1 AS x) t82 ON t1.x = t82.x JOIN (SELECT 1 AS x) t83 ON t1.x = t83.x JOIN (SELECT 1 AS x) t84 ON t1.x = t84.x JOIN (SELECT 1 AS x) t85 ON t1.x = t85.x JOIN (SELECT 1 AS x) t86 ON t1.x = t86.x JOIN (SELECT 1 AS x) t87 ON t1.x = t87.x JOIN (SELECT 1 AS x) t88 ON t1.x = t88.x JOIN (SELECT 1 AS x) t89 ON t1.x = t89.x JOIN (SELECT 1 AS x) t90 ON t1.x = t90.x JOIN (SELECT 1 AS x) t91 ON t1.x = t91.x JOIN (SELECT 1 AS x) t92 ON t1.x = t92.x JOIN (SELECT 1 AS x) t93 ON t1.x = t93.x JOIN (SELECT 1 AS x) t94 ON t1.x = t94.x JOIN (SELECT 1 AS x) t95 ON t1.x = t95.x JOIN (SELECT 1 AS x) t96 ON t1.x = t96.x JOIN (SELECT 1 AS x) t97 ON t1.x = t97.x JOIN (SELECT 1 AS x) t98 ON t1.x = t98.x JOIN (SELECT 1 AS x) t99 ON t1.x = t99.x JOIN (SELECT 1 AS x) t100 ON t1.x = t100.x JOIN (SELECT 1 AS x) t101 ON t1.x = t101.x JOIN (SELECT 1 AS x) t102 ON t1.x = t102.x JOIN (SELECT 1 AS x) t103 ON t1.x = t103.x JOIN (SELECT 1 AS x) t104 ON t1.x = t104.x JOIN (SELECT 1 AS x) t105 ON t1.x = t105.x JOIN (SELECT 1 AS x) t106 ON t1.x = t106.x JOIN (SELECT 1 AS x) t107 ON t1.x = t107.x JOIN (SELECT 1 AS x) t108 ON t1.x = t108.x JOIN (SELECT 1 AS x) t109 ON t1.x = t109.x JOIN (SELECT 1 AS x) t110 ON t1.x = t110.x JOIN (SELECT 1 AS x) t111 ON t1.x = t111.x JOIN (SELECT 1 AS x) t112 ON t1.x = t112.x JOIN (SELECT 1 AS x) t113 ON t1.x = t113.x JOIN (SELECT 1 AS x) t114 ON t1.x = t114.x JOIN (SELECT 1 AS x) t115 ON t1.x = t115.x JOIN (SELECT 1 AS x) t116 ON t1.x = t116.x JOIN (SELECT 1 AS x) t117 ON t1.x = t117.x JOIN (SELECT 1 AS x) t118 ON t1.x = t118.x JOIN (SELECT 1 AS x) t119 ON t1.x = t119.x JOIN (SELECT 1 AS x) t120 ON t1.x = t120.x JOIN (SELECT 1 AS x) t121 ON t1.x = t121.x JOIN (SELECT 1 AS x) t122 ON t1.x = t122.x JOIN (SELECT 1 AS x) t123 ON t1.x = t123.x JOIN (SELECT 1 AS x) t124 ON t1.x = t124.x JOIN (SELECT 1 AS x) t125 ON t1.x = t125.x JOIN (SELECT 1 AS x) t126 ON t1.x = t126.x JOIN (SELECT 1 AS x) t127 ON t1.x = t127.x JOIN (SELECT 1 AS x) t128 ON t1.x = t128.x JOIN (SELECT 1 AS x) t129 ON t1.x = t129.x JOIN (SELECT 1 AS x) t130 ON t1.x = t130.x JOIN (SELECT 1 AS x) t131 ON t1.x = t131.x JOIN (SELECT 1 AS x) t132 ON t1.x = t132.x JOIN (SELECT 1 AS x) t133 ON t1.x = t133.x JOIN (SELECT 1 AS x) t134 ON t1.x = t134.x JOIN (SELECT 1 AS x) t135 ON t1.x = t135.x JOIN (SELECT 1 AS x) t136 ON t1.x = t136.x JOIN (SELECT 1 AS x) t137 ON t1.x = t137.x JOIN (SELECT 1 AS x) t138 ON t1.x = t138.x JOIN (SELECT 1 AS x) t139 ON t1.x = t139.x JOIN (SELECT 1 AS x) t140 ON t1.x = t140.x JOIN (SELECT 1 AS x) t141 ON t1.x = t141.x JOIN (SELECT 1 AS x) t142 ON t1.x = t142.x JOIN (SELECT 1 AS x) t143 ON t1.x = t143.x JOIN (SELECT 1 AS x) t144 ON t1.x = t144.x JOIN (SELECT 1 AS x) t145 ON t1.x = t145.x JOIN (SELECT 1 AS x) t146 ON t1.x = t146.x JOIN (SELECT 1 AS x) t147 ON t1.x = t147.x JOIN (SELECT 1 AS x) t148 ON t1.x = t148.x JOIN (SELECT 1 AS x) t149 ON t1.x = t149.x JOIN (SELECT 1 AS x) t150 ON t1.x = t150.x JOIN (SELECT 1 AS x) t151 ON t1.x = t151.x JOIN (SELECT 1 AS x) t152 ON t1.x = t152.x JOIN (SELECT 1 AS x) t153 ON t1.x = t153.x JOIN (SELECT 1 AS x) t154 ON t1.x = t154.x JOIN (SELECT 1 AS x) t155 ON t1.x = t155.x JOIN (SELECT 1 AS x) t156 ON t1.x = t156.x JOIN (SELECT 1 AS x) t157 ON t1.x = t157.x JOIN (SELECT 1 AS x) t158 ON t1.x = t158.x JOIN (SELECT 1 AS x) t159 ON t1.x = t159.x JOIN (SELECT 1 AS x) t160 ON t1.x = t160.x JOIN (SELECT 1 AS x) t161 ON t1.x = t161.x JOIN (SELECT 1 AS x) t162 ON t1.x = t162.x JOIN (SELECT 1 AS x) t163 ON t1.x = t163.x JOIN (SELECT 1 AS x) t164 ON t1.x = t164.x JOIN (SELECT 1 AS x) t165 ON t1.x = t165.x JOIN (SELECT 1 AS x) t166 ON t1.x = t166.x JOIN (SELECT 1 AS x) t167 ON t1.x = t167.x JOIN (SELECT 1 AS x) t168 ON t1.x = t168.x JOIN (SELECT 1 AS x) t169 ON t1.x = t169.x JOIN (SELECT 1 AS x) t170 ON t1.x = t170.x JOIN (SELECT 1 AS x) t171 ON t1.x = t171.x JOIN (SELECT 1 AS x) t172 ON t1.x = t172.x JOIN (SELECT 1 AS x) t173 ON t1.x = t173.x JOIN (SELECT 1 AS x) t174 ON t1.x = t174.x JOIN (SELECT 1 AS x) t175 ON t1.x = t175.x JOIN (SELECT 1 AS x) t176 ON t1.x = t176.x JOIN (SELECT 1 AS x) t177 ON t1.x = t177.x JOIN (SELECT 1 AS x) t178 ON t1.x = t178.x JOIN (SELECT 1 AS x) t179 ON t1.x = t179.x JOIN (SELECT 1 AS x) t180 ON t1.x = t180.x JOIN (SELECT 1 AS x) t181 ON t1.x = t181.x JOIN (SELECT 1 AS x) t182 ON t1.x = t182.x JOIN (SELECT 1 AS x) t183 ON t1.x = t183.x JOIN (SELECT 1 AS x) t184 ON t1.x = t184.x JOIN (SELECT 1 AS x) t185 ON t1.x = t185.x JOIN (SELECT 1 AS x) t186 ON t1.x = t186.x JOIN (SELECT 1 AS x) t187 ON t1.x = t187.x JOIN (SELECT 1 AS x) t188 ON t1.x = t188.x JOIN (SELECT 1 AS x) t189 ON t1.x = t189.x JOIN (SELECT 1 AS x) t190 ON t1.x = t190.x JOIN (SELECT 1 AS x) t191 ON t1.x = t191.x JOIN (SELECT 1 AS x) t192 ON t1.x = t192.x JOIN (SELECT 1 AS x) t193 ON t1.x = t193.x JOIN (SELECT 1 AS x) t194 ON t1.x = t194.x JOIN (SELECT 1 AS x) t195 ON t1.x = t195.x JOIN (SELECT 1 AS x) t196 ON t1.x = t196.x JOIN (SELECT 1 AS x) t197 ON t1.x = t197.x JOIN (SELECT 1 AS x) t198 ON t1.x = t198.x JOIN (SELECT 1 AS x) t199 ON t1.x = t199.x JOIN (SELECT 1 AS x) t200 ON t1.x = t200.x JOIN (SELECT 1 AS x) t201 ON t1.x = t201.x JOIN (SELECT 1 AS x) t202 ON t1.x = t202.x JOIN (SELECT 1 AS x) t203 ON t1.x = t203.x JOIN (SELECT 1 AS x) t204 ON t1.x = t204.x JOIN (SELECT 1 AS x) t205 ON t1.x = t205.x JOIN (SELECT 1 AS x) t206 ON t1.x = t206.x JOIN (SELECT 1 AS x) t207 ON t1.x = t207.x JOIN (SELECT 1 AS x) t208 ON t1.x = t208.x JOIN (SELECT 1 AS x) t209 ON t1.x = t209.x JOIN (SELECT 1 AS x) t210 ON t1.x = t210.x JOIN (SELECT 1 AS x) t211 ON t1.x = t211.x JOIN (SELECT 1 AS x) t212 ON t1.x = t212.x JOIN (SELECT 1 AS x) t213 ON t1.x = t213.x JOIN (SELECT 1 AS x) t214 ON t1.x = t214.x JOIN (SELECT 1 AS x) t215 ON t1.x = t215.x JOIN (SELECT 1 AS x) t216 ON t1.x = t216.x JOIN (SELECT 1 AS x) t217 ON t1.x = t217.x JOIN (SELECT 1 AS x) t218 ON t1.x = t218.x JOIN (SELECT 1 AS x) t219 ON t1.x = t219.x JOIN (SELECT 1 AS x) t220 ON t1.x = t220.x JOIN (SELECT 1 AS x) t221 ON t1.x = t221.x JOIN (SELECT 1 AS x) t222 ON t1.x = t222.x JOIN (SELECT 1 AS x) t223 ON t1.x = t223.x JOIN (SELECT 1 AS x) t224 ON t1.x = t224.x JOIN (SELECT 1 AS x) t225 ON t1.x = t225.x JOIN (SELECT 1 AS x) t226 ON t1.x = t226.x JOIN (SELECT 1 AS x) t227 ON t1.x = t227.x JOIN (SELECT 1 AS x) t228 ON t1.x = t228.x JOIN (SELECT 1 AS x) t229 ON t1.x = t229.x JOIN (SELECT 1 AS x) t230 ON t1.x = t230.x JOIN (SELECT 1 AS x) t231 ON t1.x = t231.x JOIN (SELECT 1 AS x) t232 ON t1.x = t232.x JOIN (SELECT 1 AS x) t233 ON t1.x = t233.x JOIN (SELECT 1 AS x) t234 ON t1.x = t234.x JOIN (SELECT 1 AS x) t235 ON t1.x = t235.x JOIN (SELECT 1 AS x) t236 ON t1.x = t236.x JOIN (SELECT 1 AS x) t237 ON t1.x = t237.x JOIN (SELECT 1 AS x) t238 ON t1.x = t238.x JOIN (SELECT 1 AS x) t239 ON t1.x = t239.x JOIN (SELECT 1 AS x) t240 ON t1.x = t240.x JOIN (SELECT 1 AS x) t241 ON t1.x = t241.x JOIN (SELECT 1 AS x) t242 ON t1.x = t242.x JOIN (SELECT 1 AS x) t243 ON t1.x = t243.x JOIN (SELECT 1 AS x) t244 ON t1.x = t244.x JOIN (SELECT 1 AS x) t245 ON t1.x = t245.x JOIN (SELECT 1 AS x) t246 ON t1.x = t246.x JOIN (SELECT 1 AS x) t247 ON t1.x = t247.x JOIN (SELECT 1 AS x) t248 ON t1.x = t248.x JOIN (SELECT 1 AS x) t249 ON t1.x = t249.x JOIN (SELECT 1 AS x) t250 ON t1.x = t250.x JOIN (SELECT 1 AS x) t251 ON t1.x = t251.x JOIN (SELECT 1 AS x) t252 ON t1.x = t252.x JOIN (SELECT 1 AS x) t253 ON t1.x = t253.x JOIN (SELECT 1 AS x) t254 ON t1.x = t254.x JOIN (SELECT 1 AS x) t255 ON t1.x = t255.x JOIN (SELECT 1 AS x) t256 ON t1.x = t256.x JOIN (SELECT 1 AS x) t257 ON t1.x = t257.x JOIN (SELECT 1 AS x) t258 ON t1.x = t258.x JOIN (SELECT 1 AS x) t259 ON t1.x = t259.x JOIN (SELECT 1 AS x) t260 ON t1.x = t260.x JOIN (SELECT 1 AS x) t261 ON t1.x = t261.x JOIN (SELECT 1 AS x) t262 ON t1.x = t262.x JOIN (SELECT 1 AS x) t263 ON t1.x = t263.x JOIN (SELECT 1 AS x) t264 ON t1.x = t264.x JOIN (SELECT 1 AS x) t265 ON t1.x = t265.x JOIN (SELECT 1 AS x) t266 ON t1.x = t266.x JOIN (SELECT 1 AS x) t267 ON t1.x = t267.x JOIN (SELECT 1 AS x) t268 ON t1.x = t268.x JOIN (SELECT 1 AS x) t269 ON t1.x = t269.x JOIN (SELECT 1 AS x) t270 ON t1.x = t270.x JOIN (SELECT 1 AS x) t271 ON t1.x = t271.x JOIN (SELECT 1 AS x) t272 ON t1.x = t272.x JOIN (SELECT 1 AS x) t273 ON t1.x = t273.x JOIN (SELECT 1 AS x) t274 ON t1.x = t274.x JOIN (SELECT 1 AS x) t275 ON t1.x = t275.x JOIN (SELECT 1 AS x) t276 ON t1.x = t276.x JOIN (SELECT 1 AS x) t277 ON t1.x = t277.x JOIN (SELECT 1 AS x) t278 ON t1.x = t278.x JOIN (SELECT 1 AS x) t279 ON t1.x = t279.x JOIN (SELECT 1 AS x) t280 ON t1.x = t280.x JOIN (SELECT 1 AS x) t281 ON t1.x = t281.x JOIN (SELECT 1 AS x) t282 ON t1.x = t282.x JOIN (SELECT 1 AS x) t283 ON t1.x = t283.x JOIN (SELECT 1 AS x) t284 ON t1.x = t284.x JOIN (SELECT 1 AS x) t285 ON t1.x = t285.x JOIN (SELECT 1 AS x) t286 ON t1.x = t286.x JOIN (SELECT 1 AS x) t287 ON t1.x = t287.x JOIN (SELECT 1 AS x) t288 ON t1.x = t288.x JOIN (SELECT 1 AS x) t289 ON t1.x = t289.x JOIN (SELECT 1 AS x) t290 ON t1.x = t290.x JOIN (SELECT 1 AS x) t291 ON t1.x = t291.x JOIN (SELECT 1 AS x) t292 ON t1.x = t292.x JOIN (SELECT 1 AS x) t293 ON t1.x = t293.x JOIN (SELECT 1 AS x) t294 ON t1.x = t294.x JOIN (SELECT 1 AS x) t295 ON t1.x = t295.x JOIN (SELECT 1 AS x) t296 ON t1.x = t296.x JOIN (SELECT 1 AS x) t297 ON t1.x = t297.x JOIN (SELECT 1 AS x) t298 ON t1.x = t298.x JOIN (SELECT 1 AS x) t299 ON t1.x = t299.x JOIN (SELECT 1 AS x) t300 ON t1.x = t300.x JOIN (SELECT 1 AS x) t301 ON t1.x = t301.x JOIN (SELECT 1 AS x) t302 ON t1.x = t302.x JOIN (SELECT 1 AS x) t303 ON t1.x = t303.x JOIN (SELECT 1 AS x) t304 ON t1.x = t304.x JOIN (SELECT 1 AS x) t305 ON t1.x = t305.x JOIN (SELECT 1 AS x) t306 ON t1.x = t306.x JOIN (SELECT 1 AS x) t307 ON t1.x = t307.x JOIN (SELECT 1 AS x) t308 ON t1.x = t308.x JOIN (SELECT 1 AS x) t309 ON t1.x = t309.x JOIN (SELECT 1 AS x) t310 ON t1.x = t310.x JOIN (SELECT 1 AS x) t311 ON t1.x = t311.x JOIN (SELECT 1 AS x) t312 ON t1.x = t312.x JOIN (SELECT 1 AS x) t313 ON t1.x = t313.x JOIN (SELECT 1 AS x) t314 ON t1.x = t314.x JOIN (SELECT 1 AS x) t315 ON t1.x = t315.x JOIN (SELECT 1 AS x) t316 ON t1.x = t316.x JOIN (SELECT 1 AS x) t317 ON t1.x = t317.x JOIN (SELECT 1 AS x) t318 ON t1.x = t318.x JOIN (SELECT 1 AS x) t319 ON t1.x = t319.x JOIN (SELECT 1 AS x) t320 ON t1.x = t320.x JOIN (SELECT 1 AS x) t321 ON t1.x = t321.x JOIN (SELECT 1 AS x) t322 ON t1.x = t322.x JOIN (SELECT 1 AS x) t323 ON t1.x = t323.x JOIN (SELECT 1 AS x) t324 ON t1.x = t324.x JOIN (SELECT 1 AS x) t325 ON t1.x = t325.x JOIN (SELECT 1 AS x) t326 ON t1.x = t326.x JOIN (SELECT 1 AS x) t327 ON t1.x = t327.x JOIN (SELECT 1 AS x) t328 ON t1.x = t328.x JOIN (SELECT 1 AS x) t329 ON t1.x = t329.x JOIN (SELECT 1 AS x) t330 ON t1.x = t330.x JOIN (SELECT 1 AS x) t331 ON t1.x = t331.x JOIN (SELECT 1 AS x) t332 ON t1.x = t332.x JOIN (SELECT 1 AS x) t333 ON t1.x = t333.x JOIN (SELECT 1 AS x) t334 ON t1.x = t334.x JOIN (SELECT 1 AS x) t335 ON t1.x = t335.x JOIN (SELECT 1 AS x) t336 ON t1.x = t336.x JOIN (SELECT 1 AS x) t337 ON t1.x = t337.x JOIN (SELECT 1 AS x) t338 ON t1.x = t338.x JOIN (SELECT 1 AS x) t339 ON t1.x = t339.x JOIN (SELECT 1 AS x) t340 ON t1.x = t340.x JOIN (SELECT 1 AS x) t341 ON t1.x = t341.x JOIN (SELECT 1 AS x) t342 ON t1.x = t342.x JOIN (SELECT 1 AS x) t343 ON t1.x = t343.x JOIN (SELECT 1 AS x) t344 ON t1.x = t344.x JOIN (SELECT 1 AS x) t345 ON t1.x = t345.x JOIN (SELECT 1 AS x) t346 ON t1.x = t346.x JOIN (SELECT 1 AS x) t347 ON t1.x = t347.x JOIN (SELECT 1 AS x) t348 ON t1.x = t348.x JOIN (SELECT 1 AS x) t349 ON t1.x = t349.x JOIN (SELECT 1 AS x) t350 ON t1.x = t350.x JOIN (SELECT 1 AS x) t351 ON t1.x = t351.x JOIN (SELECT 1 AS x) t352 ON t1.x = t352.x JOIN (SELECT 1 AS x) t353 ON t1.x = t353.x JOIN (SELECT 1 AS x) t354 ON t1.x = t354.x JOIN (SELECT 1 AS x) t355 ON t1.x = t355.x JOIN (SELECT 1 AS x) t356 ON t1.x = t356.x JOIN (SELECT 1 AS x) t357 ON t1.x = t357.x JOIN (SELECT 1 AS x) t358 ON t1.x = t358.x JOIN (SELECT 1 AS x) t359 ON t1.x = t359.x JOIN (SELECT 1 AS x) t360 ON t1.x = t360.x JOIN (SELECT 1 AS x) t361 ON t1.x = t361.x JOIN (SELECT 1 AS x) t362 ON t1.x = t362.x JOIN (SELECT 1 AS x) t363 ON t1.x = t363.x JOIN (SELECT 1 AS x) t364 ON t1.x = t364.x JOIN (SELECT 1 AS x) t365 ON t1.x = t365.x JOIN (SELECT 1 AS x) t366 ON t1.x = t366.x JOIN (SELECT 1 AS x) t367 ON t1.x = t367.x JOIN (SELECT 1 AS x) t368 ON t1.x = t368.x JOIN (SELECT 1 AS x) t369 ON t1.x = t369.x JOIN (SELECT 1 AS x) t370 ON t1.x = t370.x JOIN (SELECT 1 AS x) t371 ON t1.x = t371.x JOIN (SELECT 1 AS x) t372 ON t1.x = t372.x JOIN (SELECT 1 AS x) t373 ON t1.x = t373.x JOIN (SELECT 1 AS x) t374 ON t1.x = t374.x JOIN (SELECT 1 AS x) t375 ON t1.x = t375.x JOIN (SELECT 1 AS x) t376 ON t1.x = t376.x JOIN (SELECT 1 AS x) t377 ON t1.x = t377.x JOIN (SELECT 1 AS x) t378 ON t1.x = t378.x JOIN (SELECT 1 AS x) t379 ON t1.x = t379.x JOIN (SELECT 1 AS x) t380 ON t1.x = t380.x JOIN (SELECT 1 AS x) t381 ON t1.x = t381.x JOIN (SELECT 1 AS x) t382 ON t1.x = t382.x JOIN (SELECT 1 AS x) t383 ON t1.x = t383.x JOIN (SELECT 1 AS x) t384 ON t1.x = t384.x JOIN (SELECT 1 AS x) t385 ON t1.x = t385.x JOIN (SELECT 1 AS x) t386 ON t1.x = t386.x JOIN (SELECT 1 AS x) t387 ON t1.x = t387.x JOIN (SELECT 1 AS x) t388 ON t1.x = t388.x JOIN (SELECT 1 AS x) t389 ON t1.x = t389.x JOIN (SELECT 1 AS x) t390 ON t1.x = t390.x JOIN (SELECT 1 AS x) t391 ON t1.x = t391.x JOIN (SELECT 1 AS x) t392 ON t1.x = t392.x JOIN (SELECT 1 AS x) t393 ON t1.x = t393.x JOIN (SELECT 1 AS x) t394 ON t1.x = t394.x JOIN (SELECT 1 AS x) t395 ON t1.x = t395.x JOIN (SELECT 1 AS x) t396 ON t1.x = t396.x JOIN (SELECT 1 AS x) t397 ON t1.x = t397.x JOIN (SELECT 1 AS x) t398 ON t1.x = t398.x JOIN (SELECT 1 AS x) t399 ON t1.x = t399.x JOIN (SELECT 1 AS x) t400 ON t1.x = t400.x JOIN (SELECT 1 AS x) t401 ON t1.x = t401.x JOIN (SELECT 1 AS x) t402 ON t1.x = t402.x JOIN (SELECT 1 AS x) t403 ON t1.x = t403.x JOIN (SELECT 1 AS x) t404 ON t1.x = t404.x JOIN (SELECT 1 AS x) t405 ON t1.x = t405.x JOIN (SELECT 1 AS x) t406 ON t1.x = t406.x JOIN (SELECT 1 AS x) t407 ON t1.x = t407.x JOIN (SELECT 1 AS x) t408 ON t1.x = t408.x JOIN (SELECT 1 AS x) t409 ON t1.x = t409.x JOIN (SELECT 1 AS x) t410 ON t1.x = t410.x JOIN (SELECT 1 AS x) t411 ON t1.x = t411.x JOIN (SELECT 1 AS x) t412 ON t1.x = t412.x JOIN (SELECT 1 AS x) t413 ON t1.x = t413.x JOIN (SELECT 1 AS x) t414 ON t1.x = t414.x JOIN (SELECT 1 AS x) t415 ON t1.x = t415.x JOIN (SELECT 1 AS x) t416 ON t1.x = t416.x JOIN (SELECT 1 AS x) t417 ON t1.x = t417.x JOIN (SELECT 1 AS x) t418 ON t1.x = t418.x JOIN (SELECT 1 AS x) t419 ON t1.x = t419.x JOIN (SELECT 1 AS x) t420 ON t1.x = t420.x JOIN (SELECT 1 AS x) t421 ON t1.x = t421.x JOIN (SELECT 1 AS x) t422 ON t1.x = t422.x JOIN (SELECT 1 AS x) t423 ON t1.x = t423.x JOIN (SELECT 1 AS x) t424 ON t1.x = t424.x JOIN (SELECT 1 AS x) t425 ON t1.x = t425.x JOIN (SELECT 1 AS x) t426 ON t1.x = t426.x JOIN (SELECT 1 AS x) t427 ON t1.x = t427.x JOIN (SELECT 1 AS x) t428 ON t1.x = t428.x JOIN (SELECT 1 AS x) t429 ON t1.x = t429.x JOIN (SELECT 1 AS x) t430 ON t1.x = t430.x JOIN (SELECT 1 AS x) t431 ON t1.x = t431.x JOIN (SELECT 1 AS x) t432 ON t1.x = t432.x JOIN (SELECT 1 AS x) t433 ON t1.x = t433.x JOIN (SELECT 1 AS x) t434 ON t1.x = t434.x JOIN (SELECT 1 AS x) t435 ON t1.x = t435.x JOIN (SELECT 1 AS x) t436 ON t1.x = t436.x JOIN (SELECT 1 AS x) t437 ON t1.x = t437.x JOIN (SELECT 1 AS x) t438 ON t1.x = t438.x JOIN (SELECT 1 AS x) t439 ON t1.x = t439.x JOIN (SELECT 1 AS x) t440 ON t1.x = t440.x JOIN (SELECT 1 AS x) t441 ON t1.x = t441.x JOIN (SELECT 1 AS x) t442 ON t1.x = t442.x JOIN (SELECT 1 AS x) t443 ON t1.x = t443.x JOIN (SELECT 1 AS x) t444 ON t1.x = t444.x JOIN (SELECT 1 AS x) t445 ON t1.x = t445.x JOIN (SELECT 1 AS x) t446 ON t1.x = t446.x JOIN (SELECT 1 AS x) t447 ON t1.x = t447.x JOIN (SELECT 1 AS x) t448 ON t1.x = t448.x JOIN (SELECT 1 AS x) t449 ON t1.x = t449.x JOIN (SELECT 1 AS x) t450 ON t1.x = t450.x JOIN (SELECT 1 AS x) t451 ON t1.x = t451.x JOIN (SELECT 1 AS x) t452 ON t1.x = t452.x JOIN (SELECT 1 AS x) t453 ON t1.x = t453.x JOIN (SELECT 1 AS x) t454 ON t1.x = t454.x JOIN (SELECT 1 AS x) t455 ON t1.x = t455.x JOIN (SELECT 1 AS x) t456 ON t1.x = t456.x JOIN (SELECT 1 AS x) t457 ON t1.x = t457.x JOIN (SELECT 1 AS x) t458 ON t1.x = t458.x JOIN (SELECT 1 AS x) t459 ON t1.x = t459.x JOIN (SELECT 1 AS x) t460 ON t1.x = t460.x JOIN (SELECT 1 AS x) t461 ON t1.x = t461.x JOIN (SELECT 1 AS x) t462 ON t1.x = t462.x JOIN (SELECT 1 AS x) t463 ON t1.x = t463.x JOIN (SELECT 1 AS x) t464 ON t1.x = t464.x JOIN (SELECT 1 AS x) t465 ON t1.x = t465.x JOIN (SELECT 1 AS x) t466 ON t1.x = t466.x JOIN (SELECT 1 AS x) t467 ON t1.x = t467.x JOIN (SELECT 1 AS x) t468 ON t1.x = t468.x JOIN (SELECT 1 AS x) t469 ON t1.x = t469.x JOIN (SELECT 1 AS x) t470 ON t1.x = t470.x JOIN (SELECT 1 AS x) t471 ON t1.x = t471.x JOIN (SELECT 1 AS x) t472 ON t1.x = t472.x JOIN (SELECT 1 AS x) t473 ON t1.x = t473.x JOIN (SELECT 1 AS x) t474 ON t1.x = t474.x JOIN (SELECT 1 AS x) t475 ON t1.x = t475.x JOIN (SELECT 1 AS x) t476 ON t1.x = t476.x JOIN (SELECT 1 AS x) t477 ON t1.x = t477.x JOIN (SELECT 1 AS x) t478 ON t1.x = t478.x JOIN (SELECT 1 AS x) t479 ON t1.x = t479.x JOIN (SELECT 1 AS x) t480 ON t1.x = t480.x JOIN (SELECT 1 AS x) t481 ON t1.x = t481.x JOIN (SELECT 1 AS x) t482 ON t1.x = t482.x JOIN (SELECT 1 AS x) t483 ON t1.x = t483.x JOIN (SELECT 1 AS x) t484 ON t1.x = t484.x JOIN (SELECT 1 AS x) t485 ON t1.x = t485.x JOIN (SELECT 1 AS x) t486 ON t1.x = t486.x JOIN (SELECT 1 AS x) t487 ON t1.x = t487.x JOIN (SELECT 1 AS x) t488 ON t1.x = t488.x JOIN (SELECT 1 AS x) t489 ON t1.x = t489.x JOIN (SELECT 1 AS x) t490 ON t1.x = t490.x JOIN (SELECT 1 AS x) t491 ON t1.x = t491.x JOIN (SELECT 1 AS x) t492 ON t1.x = t492.x JOIN (SELECT 1 AS x) t493 ON t1.x = t493.x JOIN (SELECT 1 AS x) t494 ON t1.x = t494.x JOIN (SELECT 1 AS x) t495 ON t1.x = t495.x JOIN (SELECT 1 AS x) t496 ON t1.x = t496.x JOIN (SELECT 1 AS x) t497 ON t1.x = t497.x JOIN (SELECT 1 AS x) t498 ON t1.x = t498.x JOIN (SELECT 1 AS x) t499 ON t1.x = t499.x JOIN (SELECT 1 AS x) t500 ON t1.x = t500.x JOIN (SELECT 1 AS x) t501 ON t1.x = t501.x JOIN (SELECT 1 AS x) t502 ON t1.x = t502.x JOIN (SELECT 1 AS x) t503 ON t1.x = t503.x JOIN (SELECT 1 AS x) t504 ON t1.x = t504.x JOIN (SELECT 1 AS x) t505 ON t1.x = t505.x JOIN (SELECT 1 AS x) t506 ON t1.x = t506.x JOIN (SELECT 1 AS x) t507 ON t1.x = t507.x JOIN (SELECT 1 AS x) t508 ON t1.x = t508.x JOIN (SELECT 1 AS x) t509 ON t1.x = t509.x JOIN (SELECT 1 AS x) t510 ON t1.x = t510.x JOIN (SELECT 1 AS x) t511 ON t1.x = t511.x JOIN (SELECT 1 AS x) t512 ON t1.x = t512.x JOIN (SELECT 1 AS x) t513 ON t1.x = t513.x JOIN (SELECT 1 AS x) t514 ON t1.x = t514.x JOIN (SELECT 1 AS x) t515 ON t1.x = t515.x JOIN (SELECT 1 AS x) t516 ON t1.x = t516.x JOIN (SELECT 1 AS x) t517 ON t1.x = t517.x JOIN (SELECT 1 AS x) t518 ON t1.x = t518.x JOIN (SELECT 1 AS x) t519 ON t1.x = t519.x JOIN (SELECT 1 AS x) t520 ON t1.x = t520.x JOIN (SELECT 1 AS x) t521 ON t1.x = t521.x JOIN (SELECT 1 AS x) t522 ON t1.x = t522.x JOIN (SELECT 1 AS x) t523 ON t1.x = t523.x JOIN (SELECT 1 AS x) t524 ON t1.x = t524.x JOIN (SELECT 1 AS x) t525 ON t1.x = t525.x JOIN (SELECT 1 AS x) t526 ON t1.x = t526.x JOIN (SELECT 1 AS x) t527 ON t1.x = t527.x JOIN (SELECT 1 AS x) t528 ON t1.x = t528.x JOIN (SELECT 1 AS x) t529 ON t1.x = t529.x JOIN (SELECT 1 AS x) t530 ON t1.x = t530.x JOIN (SELECT 1 AS x) t531 ON t1.x = t531.x JOIN (SELECT 1 AS x) t532 ON t1.x = t532.x JOIN (SELECT 1 AS x) t533 ON t1.x = t533.x JOIN (SELECT 1 AS x) t534 ON t1.x = t534.x JOIN (SELECT 1 AS x) t535 ON t1.x = t535.x JOIN (SELECT 1 AS x) t536 ON t1.x = t536.x JOIN (SELECT 1 AS x) t537 ON t1.x = t537.x JOIN (SELECT 1 AS x) t538 ON t1.x = t538.x JOIN (SELECT 1 AS x) t539 ON t1.x = t539.x JOIN (SELECT 1 AS x) t540 ON t1.x = t540.x JOIN (SELECT 1 AS x) t541 ON t1.x = t541.x JOIN (SELECT 1 AS x) t542 ON t1.x = t542.x JOIN (SELECT 1 AS x) t543 ON t1.x = t543.x JOIN (SELECT 1 AS x) t544 ON t1.x = t544.x JOIN (SELECT 1 AS x) t545 ON t1.x = t545.x JOIN (SELECT 1 AS x) t546 ON t1.x = t546.x JOIN (SELECT 1 AS x) t547 ON t1.x = t547.x JOIN (SELECT 1 AS x) t548 ON t1.x = t548.x JOIN (SELECT 1 AS x) t549 ON t1.x = t549.x JOIN (SELECT 1 AS x) t550 ON t1.x = t550.x JOIN (SELECT 1 AS x) t551 ON t1.x = t551.x JOIN (SELECT 1 AS x) t552 ON t1.x = t552.x JOIN (SELECT 1 AS x) t553 ON t1.x = t553.x JOIN (SELECT 1 AS x) t554 ON t1.x = t554.x JOIN (SELECT 1 AS x) t555 ON t1.x = t555.x JOIN (SELECT 1 AS x) t556 ON t1.x = t556.x JOIN (SELECT 1 AS x) t557 ON t1.x = t557.x JOIN (SELECT 1 AS x) t558 ON t1.x = t558.x JOIN (SELECT 1 AS x) t559 ON t1.x = t559.x JOIN (SELECT 1 AS x) t560 ON t1.x = t560.x JOIN (SELECT 1 AS x) t561 ON t1.x = t561.x JOIN (SELECT 1 AS x) t562 ON t1.x = t562.x JOIN (SELECT 1 AS x) t563 ON t1.x = t563.x JOIN (SELECT 1 AS x) t564 ON t1.x = t564.x JOIN (SELECT 1 AS x) t565 ON t1.x = t565.x JOIN (SELECT 1 AS x) t566 ON t1.x = t566.x JOIN (SELECT 1 AS x) t567 ON t1.x = t567.x JOIN (SELECT 1 AS x) t568 ON t1.x = t568.x JOIN (SELECT 1 AS x) t569 ON t1.x = t569.x JOIN (SELECT 1 AS x) t570 ON t1.x = t570.x JOIN (SELECT 1 AS x) t571 ON t1.x = t571.x JOIN (SELECT 1 AS x) t572 ON t1.x = t572.x JOIN (SELECT 1 AS x) t573 ON t1.x = t573.x JOIN (SELECT 1 AS x) t574 ON t1.x = t574.x JOIN (SELECT 1 AS x) t575 ON t1.x = t575.x JOIN (SELECT 1 AS x) t576 ON t1.x = t576.x JOIN (SELECT 1 AS x) t577 ON t1.x = t577.x JOIN (SELECT 1 AS x) t578 ON t1.x = t578.x JOIN (SELECT 1 AS x) t579 ON t1.x = t579.x JOIN (SELECT 1 AS x) t580 ON t1.x = t580.x JOIN (SELECT 1 AS x) t581 ON t1.x = t581.x JOIN (SELECT 1 AS x) t582 ON t1.x = t582.x JOIN (SELECT 1 AS x) t583 ON t1.x = t583.x JOIN (SELECT 1 AS x) t584 ON t1.x = t584.x JOIN (SELECT 1 AS x) t585 ON t1.x = t585.x JOIN (SELECT 1 AS x) t586 ON t1.x = t586.x JOIN (SELECT 1 AS x) t587 ON t1.x = t587.x JOIN (SELECT 1 AS x) t588 ON t1.x = t588.x JOIN (SELECT 1 AS x) t589 ON t1.x = t589.x JOIN (SELECT 1 AS x) t590 ON t1.x = t590.x JOIN (SELECT 1 AS x) t591 ON t1.x = t591.x JOIN (SELECT 1 AS x) t592 ON t1.x = t592.x JOIN (SELECT 1 AS x) t593 ON t1.x = t593.x JOIN (SELECT 1 AS x) t594 ON t1.x = t594.x JOIN (SELECT 1 AS x) t595 ON t1.x = t595.x JOIN (SELECT 1 AS x) t596 ON t1.x = t596.x JOIN (SELECT 1 AS x) t597 ON t1.x = t597.x JOIN (SELECT 1 AS x) t598 ON t1.x = t598.x JOIN (SELECT 1 AS x) t599 ON t1.x = t599.x JOIN (SELECT 1 AS x) t600 ON t1.x = t600.x JOIN (SELECT 1 AS x) t601 ON t1.x = t601.x JOIN (SELECT 1 AS x) t602 ON t1.x = t602.x JOIN (SELECT 1 AS x) t603 ON t1.x = t603.x JOIN (SELECT 1 AS x) t604 ON t1.x = t604.x JOIN (SELECT 1 AS x) t605 ON t1.x = t605.x JOIN (SELECT 1 AS x) t606 ON t1.x = t606.x JOIN (SELECT 1 AS x) t607 ON t1.x = t607.x JOIN (SELECT 1 AS x) t608 ON t1.x = t608.x JOIN (SELECT 1 AS x) t609 ON t1.x = t609.x JOIN (SELECT 1 AS x) t610 ON t1.x = t610.x JOIN (SELECT 1 AS x) t611 ON t1.x = t611.x JOIN (SELECT 1 AS x) t612 ON t1.x = t612.x JOIN (SELECT 1 AS x) t613 ON t1.x = t613.x JOIN (SELECT 1 AS x) t614 ON t1.x = t614.x JOIN (SELECT 1 AS x) t615 ON t1.x = t615.x JOIN (SELECT 1 AS x) t616 ON t1.x = t616.x JOIN (SELECT 1 AS x) t617 ON t1.x = t617.x JOIN (SELECT 1 AS x) t618 ON t1.x = t618.x JOIN (SELECT 1 AS x) t619 ON t1.x = t619.x JOIN (SELECT 1 AS x) t620 ON t1.x = t620.x JOIN (SELECT 1 AS x) t621 ON t1.x = t621.x JOIN (SELECT 1 AS x) t622 ON t1.x = t622.x JOIN (SELECT 1 AS x) t623 ON t1.x = t623.x JOIN (SELECT 1 AS x) t624 ON t1.x = t624.x JOIN (SELECT 1 AS x) t625 ON t1.x = t625.x JOIN (SELECT 1 AS x) t626 ON t1.x = t626.x JOIN (SELECT 1 AS x) t627 ON t1.x = t627.x JOIN (SELECT 1 AS x) t628 ON t1.x = t628.x JOIN (SELECT 1 AS x) t629 ON t1.x = t629.x JOIN (SELECT 1 AS x) t630 ON t1.x = t630.x JOIN (SELECT 1 AS x) t631 ON t1.x = t631.x JOIN (SELECT 1 AS x) t632 ON t1.x = t632.x JOIN (SELECT 1 AS x) t633 ON t1.x = t633.x JOIN (SELECT 1 AS x) t634 ON t1.x = t634.x JOIN (SELECT 1 AS x) t635 ON t1.x = t635.x JOIN (SELECT 1 AS x) t636 ON t1.x = t636.x JOIN (SELECT 1 AS x) t637 ON t1.x = t637.x JOIN (SELECT 1 AS x) t638 ON t1.x = t638.x JOIN (SELECT 1 AS x) t639 ON t1.x = t639.x JOIN (SELECT 1 AS x) t640 ON t1.x = t640.x JOIN (SELECT 1 AS x) t641 ON t1.x = t641.x JOIN (SELECT 1 AS x) t642 ON t1.x = t642.x JOIN (SELECT 1 AS x) t643 ON t1.x = t643.x JOIN (SELECT 1 AS x) t644 ON t1.x = t644.x JOIN (SELECT 1 AS x) t645 ON t1.x = t645.x JOIN (SELECT 1 AS x) t646 ON t1.x = t646.x JOIN (SELECT 1 AS x) t647 ON t1.x = t647.x JOIN (SELECT 1 AS x) t648 ON t1.x = t648.x JOIN (SELECT 1 AS x) t649 ON t1.x = t649.x JOIN (SELECT 1 AS x) t650 ON t1.x = t650.x JOIN (SELECT 1 AS x) t651 ON t1.x = t651.x JOIN (SELECT 1 AS x) t652 ON t1.x = t652.x JOIN (SELECT 1 AS x) t653 ON t1.x = t653.x JOIN (SELECT 1 AS x) t654 ON t1.x = t654.x JOIN (SELECT 1 AS x) t655 ON t1.x = t655.x JOIN (SELECT 1 AS x) t656 ON t1.x = t656.x JOIN (SELECT 1 AS x) t657 ON t1.x = t657.x JOIN (SELECT 1 AS x) t658 ON t1.x = t658.x JOIN (SELECT 1 AS x) t659 ON t1.x = t659.x JOIN (SELECT 1 AS x) t660 ON t1.x = t660.x JOIN (SELECT 1 AS x) t661 ON t1.x = t661.x JOIN (SELECT 1 AS x) t662 ON t1.x = t662.x JOIN (SELECT 1 AS x) t663 ON t1.x = t663.x JOIN (SELECT 1 AS x) t664 ON t1.x = t664.x JOIN (SELECT 1 AS x) t665 ON t1.x = t665.x JOIN (SELECT 1 AS x) t666 ON t1.x = t666.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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322bdecd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322bbf48 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x00000000350103dc 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f356 7. ./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*) @ 0x000000003ae9f89d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 10. ? @ 0x00007f038ce47ac3 11. ? @ 0x00007f038ced9850 2025.03.31 19:19:27.440984 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:27.630862 [ 3464 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:28.542312 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:28.631549 [ 3441 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:29.479065 [ 3830 ] {1ba99aae-cabd-4591-bae9-9a6ffacce865} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45730) (comment: 02899_use_default_format_on_http_exception.sh) (in query: SELECT x FROM system.numbers 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 18. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 19. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 26. ? @ 0x00007f038ce47ac3 27. ? @ 0x00007f038ced9850 2025.03.31 19:19:29.483662 [ 3830 ] {1ba99aae-cabd-4591-bae9-9a6ffacce865} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 18. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 19. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 26. ? @ 0x00007f038ce47ac3 27. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:29.632297 [ 3415 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:29.661983 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:30.282776 [ 3830 ] {cf8d5a05-54e7-44a8-b022-0b577fd51da2} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58836) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:19:30.286450 [ 3830 ] {cf8d5a05-54e7-44a8-b022-0b577fd51da2} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:30.523966 [ 3830 ] {c8828cce-72df-49cd-bd85-efd246793398} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58840) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:19:30.527591 [ 3830 ] {c8828cce-72df-49cd-bd85-efd246793398} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:30.562319 [ 3830 ] {bf693beb-679e-4eac-be21-2e636b361c40} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58848) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:19:30.632959 [ 3396 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:30.744877 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:31.323242 [ 3830 ] {bf693beb-679e-4eac-be21-2e636b361c40} executeQuery: Code: 73. DB::Exception: Unknown format BADFORMAT. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:46: DB::FormatFactory::getCreators(String const&) const @ 0x000000003ac42331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x000000003ac4b4c9 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&)>)::$_1::operator()() const @ 0x00000000358bc368 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b4e22 8. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 9. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:19:31.325247 [ 3830 ] {bf693beb-679e-4eac-be21-2e636b361c40} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:31.404471 [ 3830 ] {db6cfba2-685e-4fdb-8205-0c497b147d22} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58854) (comment: 02899_use_default_format_on_http_exception.sh) (in query: SELECT x FROM system.numbers 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 18. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 19. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 26. ? @ 0x00007f038ce47ac3 27. ? @ 0x00007f038ced9850 2025.03.31 19:19:31.407698 [ 3830 ] {db6cfba2-685e-4fdb-8205-0c497b147d22} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression identifier 'x' in scope SELECT x FROM system.numbers LIMIT 1. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 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&&) @ 0x00000000334f1ae7 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003344584b 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 7. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358afdd7 18. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 19. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 24. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 25. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 26. ? @ 0x00007f038ce47ac3 27. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:31.439837 [ 3830 ] {8203b944-7aa9-4ac7-ac0a-0faa7a9c5f53} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58866) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:19:31.442703 [ 3830 ] {8203b944-7aa9-4ac7-ac0a-0faa7a9c5f53} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:31.465748 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:19:31.474290 [ 3830 ] {7f55401b-273d-4bbf-b328-498348bb1492} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58870) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:19:31.477151 [ 3830 ] {7f55401b-273d-4bbf-b328-498348bb1492} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:31.512013 [ 3830 ] {eb0e3833-d18e-43d3-82b7-7df0afe5d2b9} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58878) (comment: 02899_use_default_format_on_http_exception.sh) (in query: INSERT INTO system.numbers Select * from numbers(10); ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:19:31.513224 [ 3830 ] {eb0e3833-d18e-43d3-82b7-7df0afe5d2b9} executeQuery: Code: 73. DB::Exception: Unknown format BADFORMAT. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Formats/FormatFactory.cpp:46: DB::FormatFactory::getCreators(String const&) const @ 0x000000003ac42331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x000000003ac4b4c9 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&)>)::$_1::operator()() const @ 0x00000000358bc368 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x00000000358b4e22 8. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 9. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:19:31.514737 [ 3830 ] {eb0e3833-d18e-43d3-82b7-7df0afe5d2b9} DynamicQueryHandler: Code: 48. DB::Exception: Method write is not supported by storage SystemNumbers. (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002ffc0ee7 4. ./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&) @ 0x000000003ba5a50f 5. ./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*) @ 0x0000000034b91a81 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000034b94a8f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000034b9b220 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::execute() @ 0x0000000034ba442c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:31.633524 [ 3377 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:31.852246 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:32.634357 [ 3366 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:32.882485 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:33.635186 [ 3346 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:34.081998 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:34.404368 [ 19260 ] {54aa8c95-f4bb-4118-ad2c-a501468f0b49} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 129.923521288 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322bdecd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322bbf48 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x00000000350103dc 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:104: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f356 7. ./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*) @ 0x000000003ae9f89d 8. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 10. ? @ 0x00007f038ce47ac3 11. ? @ 0x00007f038ced9850 2025.03.31 19:19:34.635877 [ 3326 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:35.155876 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:35.636577 [ 3301 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:35.935546 [ 12294 ] {f4ec5900-e63e-4e71-9fa0-36ce2751815d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:43226) (comment: 01778_where_with_column_name.sql) (in query: DROP DATABASE IF EXISTS test_x06asxlj ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:19:35.938647 [ 12294 ] {f4ec5900-e63e-4e71-9fa0-36ce2751815d} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:36.349505 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:36.637329 [ 3312 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:37.389635 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:37.638342 [ 3276 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:38.477956 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:38.638964 [ 3253 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:39.173319 [ 19288 ] {1584e10c-47bb-4970-8f1a-dde7736bc2a3} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: Cannot parse Date from String: In scope SELECT toDate('07-08-2019'). (CANNOT_PARSE_DATE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38924) (comment: 01933_invalid_date.sql) (in query: SELECT toDate('07-08-2019');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000009619dbd 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000096199ad 5. 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&&) @ 0x0000000009324df0 6. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009315f7f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 2025.03.31 19:19:39.174868 [ 19288 ] {1584e10c-47bb-4970-8f1a-dde7736bc2a3} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: Cannot parse Date from String: In scope SELECT toDate('07-08-2019'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000009619dbd 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000096199ad 5. 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&&) @ 0x0000000009324df0 6. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009315f7f 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 15. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 30. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 2025.03.31 19:19:39.223051 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:19:39.558785 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:39.639703 [ 3235 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:40.639087 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:40.640404 [ 3213 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:40.742151 [ 19288 ] {05565214-3c6b-4ff1-8be5-03127dc37dc5} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('2019-0708'). (CANNOT_PARSE_DATE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38924) (comment: 01933_invalid_date.sql) (in query: SELECT toDate('2019-0708');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000201ce28c 5. ./build_docker/./src/IO/ReadHelpers.cpp:1428: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000201cdce8 6. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000009619593 7. 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&&) @ 0x0000000009324df0 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009315f7f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:19:40.743738 [ 19288 ] {05565214-3c6b-4ff1-8be5-03127dc37dc5} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('2019-0708'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000201ce28c 5. ./build_docker/./src/IO/ReadHelpers.cpp:1428: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000201cdce8 6. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000009619593 7. 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&&) @ 0x0000000009324df0 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009315f7f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:19:40.761384 [ 19288 ] {0019cbf3-af13-4ac8-add9-40b909738e44} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('201907-08'). (CANNOT_PARSE_DATE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38924) (comment: 01933_invalid_date.sql) (in query: SELECT toDate('201907-08');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000201ce28c 5. ./build_docker/./src/IO/ReadHelpers.cpp:1428: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000201cdce8 6. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000009619593 7. 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&&) @ 0x0000000009324df0 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009315f7f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:19:40.847103 [ 19288 ] {0019cbf3-af13-4ac8-add9-40b909738e44} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT toDate('201907-08'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/IO/ReadHelpers.cpp:1363: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x00000000201ce28c 5. ./build_docker/./src/IO/ReadHelpers.cpp:1428: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000201cdce8 6. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x0000000009619593 7. 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&&) @ 0x0000000009324df0 8. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000009315f7f 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5f9e10 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fafaf 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334a08b2 17. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 20. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 2025.03.31 19:19:41.641210 [ 3196 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:41.898406 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:42.642141 [ 3516 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:42.943861 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:43.257628 [ 19288 ] {1f0712bf-b640-4275-a4e5-1ba0ef911fb0} executeQuery: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: while converting '07-08-2019' to Date. (CANNOT_PARSE_DATE) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:38924) (comment: 01933_invalid_date.sql) (in query: SELECT * FROM test WHERE d >= '07-08-2019';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000009619dbd 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000096199ad 5. ./src/Common/LocalDate.h:117: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032673c6a 6. ./src/IO/ReadBuffer.h:106: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032673aab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357beb6b 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357b8b0d 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000010d7c8e0 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000010d3320c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003323df50 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000332390a3 18. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b7f20a8 19. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003bdf371c 20. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c575d1 21. ./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>>&) @ 0x0000000034d1372e 22. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfb8f1 23. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 24. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 25. ./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*) @ 0x000000003589fd91 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:19:43.259705 [ 19288 ] {1f0712bf-b640-4275-a4e5-1ba0ef911fb0} TCPHandler: Code: 38. DB::Exception: Cannot parse date here: 07-08-2019: while converting '07-08-2019' to Date. (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*)::'lambda'()::operator()() const @ 0x0000000009619dbd 4. void DB::readDateTextImpl(LocalDate&, DB::ReadBuffer&, char const*) @ 0x00000000096199ad 5. ./src/Common/LocalDate.h:117: DB::SerializationDate::deserializeTextEscaped(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032673c6a 6. ./src/IO/ReadBuffer.h:106: DB::SerializationDate::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000032673aab 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357beb6b 8. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x00000000357b8b0d 9. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x0000000010d7c8e0 10. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000010d3320c 11. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083769c2 12. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000083ce8bb 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fb0d1 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b5fd09f 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000b602e7e 16. ./build_docker/./src/Interpreters/ActionsDAG.cpp:0: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x000000003323df50 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000332390a3 18. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000003b7f20a8 19. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000003bdf371c 20. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000034c575d1 21. ./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>>&) @ 0x0000000034d1372e 22. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000034cfb8f1 23. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000034ce9a12 24. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000034ce22d2 25. ./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*) @ 0x000000003589fd91 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 28. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 2025.03.31 19:19:43.642871 [ 3187 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:43.666318 [ 12294 ] {9e1bb162-2989-4a38-8713-4a3fc54c5bf1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57128) (comment: 00387_use_client_time_zone.sh) (in query: SELECT toDateTime(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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:19:43.668759 [ 12294 ] {9e1bb162-2989-4a38-8713-4a3fc54c5bf1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:19:44.006454 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:44.643533 [ 3168 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:45.105888 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:45.644400 [ 3149 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:45.966734 [ 19199 ] {c22b9ef0-7670-4a17-ae26-009532f743b5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57168) (comment: 00326_long_function_multi_if.sql) (in query: SELECT 'Numeric branches';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:19:45.970269 [ 19199 ] {c22b9ef0-7670-4a17-ae26-009532f743b5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:19:46.333276 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:46.645624 [ 3121 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:47.379319 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:19:47.441489 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:47.646549 [ 3104 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:48.096765 [ 19288 ] {d33d5927-49dc-4869-943b-2d74b0a47b71} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing): In scope SELECT initializeAggregation('sumMap', [1, 2, 1], [1, 1, 1], [NULL, NULL, NULL]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:57194) (comment: 01634_sum_map_nulls.sql) (in query: SELECT initializeAggregation('sumMap', [1, 2, 1], [1, 1, 1], [null, null, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:131: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002db93ca7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dbb01 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d6259 7. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:451: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fc56df7 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306db675 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d6259 10. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012f0fcd6 11. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 2025.03.31 19:19:48.098658 [ 19288 ] {d33d5927-49dc-4869-943b-2d74b0a47b71} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nullable(Nothing): In scope SELECT initializeAggregation('sumMap', [1, 2, 1], [1, 1, 1], [NULL, NULL, NULL]). (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x00000000083e062a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSumMap.cpp:131: std::shared_ptr std::__function::__policy_invoker (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>::__call_impl (String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*)>>(std::__function::__policy_storage const*, String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002db93ca7 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:211: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306dbb01 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d6259 7. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:451: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x000000002fc56df7 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000306db675 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000306d6259 10. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012f0fcd6 11. DB::FunctionToOverloadResolverAdaptor::getReturnTypeImpl(std::vector> const&) const @ 0x00000000083cb9bf 12. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000b605e57 13. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000b6050da 14. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000b606dcc 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000003349fc4d 16. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000003343f426 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x000000003343c6b1 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000334d6400 19. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000033427202 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000033423c06 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:0: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000334220f9 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000003496eb19 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&) @ 0x0000000034ce03e4 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&) @ 0x0000000034cd7a2e 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&) @ 0x0000000034ce2e55 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&) @ 0x0000000034ce29b3 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000034b7e0cc 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*) @ 0x000000003589f337 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 31. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 2025.03.31 19:19:48.647303 [ 3092 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:48.672242 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:49.648184 [ 3068 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:49.747221 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:50.649170 [ 3053 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:50.849201 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:51.650186 [ 3034 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:51.912472 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:52.138255 [ 19288 ] {ea2dac72-2fdf-43b7-9062-66a402a61426} Context: An error has occurred while reloading storage policies, storage policies were not applied: volume_priority values must be unique across the policy 2025.03.31 19:19:52.650954 [ 3027 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:53.004406 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:53.651953 [ 3009 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:53.895195 [ 19288 ] {c7ace6ec-81ab-4051-ac21-8aabc9159fda} Context: An error has occurred while reloading storage policies, storage policies were not applied: volume_priority values must cover the range from 1 to N (lowest priority specified) without gaps 2025.03.31 19:19:54.067602 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:54.652820 [ 3485 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:55.134065 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:55.434761 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:19:55.653537 [ 3469 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:56.333061 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:56.654316 [ 3445 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:57.434912 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:57.655035 [ 3433 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:58.457532 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:58.655698 [ 3422 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:19:59.499361 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:19:59.656433 [ 3412 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:00.576869 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:00.657328 [ 3369 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:01.147095 [ 3600 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f7684ad4-5a51-47e0-b9af-e4cdeab38f3a::202503_141_171_6}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:01.599745 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:01.658150 [ 3331 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:01.960372 [ 3596 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f7684ad4-5a51-47e0-b9af-e4cdeab38f3a::202503_141_171_6}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:02.658879 [ 3306 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:02.661976 [ 12294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:03.394096 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:20:03.659582 [ 3286 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:03.732566 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:04.343612 [ 19288 ] {35758d1a-40aa-499c-bbd3-9101ede851ea} executeQuery: Code: 57. DB::Exception: Table test_1.defaulted already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50002) (comment: 00079_defaulted_columns.sql) (in query: create table defaulted (col1 UInt32, col2 default col1 + 1, col3 materialized col1 + 2, col4 alias col1 + 3) 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:20:04.345073 [ 19288 ] {35758d1a-40aa-499c-bbd3-9101ede851ea} TCPHandler: Code: 57. DB::Exception: Table test_1.defaulted 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:20:04.660289 [ 3270 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:04.808204 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:05.661032 [ 3260 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:05.843176 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:06.045020 [ 12294 ] {286110b1-3b51-4e96-a46b-1e6b0ea536e5} executeQuery: Code: 80. DB::Exception: Create table with statistics is now disabled. Turn on allow_experimental_statistics. (INCORRECT_QUERY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50022) (comment: 02864_statistics_ddl.sql) (in query: -- Error case: Can't create statistics when allow_experimental_statistics = 0 CREATE TABLE tab (col Float64 STATISTICS(tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489a154 5. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 6. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:20:06.047024 [ 12294 ] {286110b1-3b51-4e96-a46b-1e6b0ea536e5} TCPHandler: Code: 80. DB::Exception: Create table with statistics is now disabled. Turn on allow_experimental_statistics. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x000000003489a154 5. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 6. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 15. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 16. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 2025.03.31 19:20:06.676728 [ 3233 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:06.968019 [ 19288 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:07.257142 [ 12294 ] {1c6ba970-bb89-452d-b82a-e90c49b18baa} executeQuery: Code: 80. DB::Exception: Unknown statistics type: no_statistics_type. Supported statistics types are 'tdigest', 'uniq' and 'count_min'. (INCORRECT_QUERY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50022) (comment: 02864_statistics_ddl.sql) (in query: -- Error case: Unknown statistics types are rejected CREATE TABLE tab (col Float64 STATISTICS(no_statistics_type)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:54: DB::stringToStatisticsType(String) @ 0x000000003822f7ca 5. ./build_docker/./src/Storages/StatisticsDescription.cpp:183: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000038234e79 6. ./contrib/llvm-project/libcxx/include/__tree:1729: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034898381 7. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 8. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:20:07.259065 [ 12294 ] {1c6ba970-bb89-452d-b82a-e90c49b18baa} TCPHandler: Code: 80. DB::Exception: Unknown statistics type: no_statistics_type. Supported statistics types are 'tdigest', 'uniq' and 'count_min'. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000841c50a 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:54: DB::stringToStatisticsType(String) @ 0x000000003822f7ca 5. ./build_docker/./src/Storages/StatisticsDescription.cpp:183: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000038234e79 6. ./contrib/llvm-project/libcxx/include/__tree:1729: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034898381 7. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 8. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 13. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:20:07.677443 [ 3222 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:08.052472 [ 12294 ] {8e1929d5-d347-4599-a824-d80ff3e50f95} executeQuery: Code: 80. DB::Exception: Column col already contains statistics type tdigest. (INCORRECT_QUERY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50022) (comment: 02864_statistics_ddl.sql) (in query: -- Error case: The same statistics type can't exist more than once on a column CREATE TABLE tab (col Float64 STATISTICS(tdigest, tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x00000000206ab70d 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:185: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000038235639 5. ./contrib/llvm-project/libcxx/include/__tree:1729: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034898381 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:08.054152 [ 12294 ] {8e1929d5-d347-4599-a824-d80ff3e50f95} TCPHandler: Code: 80. DB::Exception: Column col already contains statistics type tdigest. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String const&) @ 0x00000000206ab70d 4. ./build_docker/./src/Storages/StatisticsDescription.cpp:185: DB::ColumnStatisticsDescription::fromColumnDeclaration(DB::ASTColumnDeclaration const&, std::shared_ptr) @ 0x0000000038235639 5. ./contrib/llvm-project/libcxx/include/__tree:1729: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x0000000034898381 6. ./contrib/boost/boost/multi_index_container.hpp:1000: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x000000003489d3c7 7. ./src/Parsers/ASTCreateQuery.h:175: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348b6c77 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:08.111330 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:08.211497 [ 12294 ] {c7f2ff3a-9260-462e-92fb-824a7faf249a} executeQuery: Code: 57. DB::Exception: Table test_1.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:50022) (comment: 02864_statistics_ddl.sql) (in query: CREATE TABLE tab (col UInt256 STATISTICS(tdigest)) Engine = MergeTree() ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:20:08.212860 [ 12294 ] {c7f2ff3a-9260-462e-92fb-824a7faf249a} TCPHandler: Code: 57. DB::Exception: Table test_1.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000837d66d 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1558: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000348d7574 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000348bb50a 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1986: DB::InterpreterCreateQuery::execute() @ 0x00000000348e3216 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000035893efd 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:723: DB::TCPHandler::runImpl() @ 0x000000003ab94c38 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:20:08.678510 [ 3502 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:09.154900 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:09.679221 [ 3185 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:10.197022 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:10.679744 [ 3177 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:10.840560 [ 31777 ] {d601c470-444b-441e-be45-fce0bd71e348} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=740). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:42294) (comment: 01683_text_log_deadlock.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:20:10.843918 [ 31777 ] {d601c470-444b-441e-be45-fce0bd71e348} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=795, jobs=740). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x000000003ae9b78c 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000003ae9ce0b 8. ./build_docker/./src/Server/TCPHandler.cpp:1108: DB::TCPHandler::processOrdinaryQuery() @ 0x000000003abb7385 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab94f78 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 14. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 15. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 16. ? @ 0x00007f038ce47ac3 17. ? @ 0x00007f038ced9850 2025.03.31 19:20:11.221974 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:11.680346 [ 3157 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:12.281961 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:12.333954 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:20:12.681310 [ 3130 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:13.349033 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:13.682217 [ 3111 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:14.439264 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:14.683132 [ 3097 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:15.552813 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:15.683870 [ 3077 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:16.590396 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:16.684623 [ 3054 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:17.670399 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:17.685368 [ 3032 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:18.686347 [ 3030 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:18.707245 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:19.687050 [ 3008 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:19.843501 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:20.423875 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:20:20.687686 [ 3486 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:20.941886 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:21.688633 [ 3461 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:22.042172 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:22.689467 [ 3460 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:23.116721 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:23.690154 [ 3431 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:24.154403 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:24.690876 [ 3408 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:25.167542 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:25.691822 [ 3399 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:26.199803 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:26.692640 [ 3386 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:27.274323 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:27.693395 [ 3355 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:28.163267 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:20:28.347929 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:28.694297 [ 3360 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:29.452411 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:29.695250 [ 3335 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:30.532935 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:30.696050 [ 3308 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:31.593111 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:31.696826 [ 3292 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:32.650534 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:32.697571 [ 3280 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:33.673138 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:33.698516 [ 3264 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:34.699272 [ 3254 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:34.701431 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:35.699988 [ 3238 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:35.833136 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:36.700744 [ 3222 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:36.940047 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:37.701455 [ 3208 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:37.989213 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:38.702177 [ 3199 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:39.071917 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:39.702897 [ 3518 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:40.165886 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:40.703670 [ 3182 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:41.227393 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:41.704560 [ 3173 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:42.338148 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:42.705515 [ 3156 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:43.370217 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:43.706262 [ 3150 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:44.387813 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:44.707074 [ 3133 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:45.436070 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:45.707849 [ 3117 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:46.488855 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:46.708642 [ 3107 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:47.575485 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:47.709522 [ 3090 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:48.611237 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:48.710373 [ 3080 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:49.711217 [ 3066 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:49.753535 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:50.711985 [ 3041 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:50.788661 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:51.712925 [ 3040 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:51.828969 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:52.713694 [ 3036 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:52.917601 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:53.714772 [ 3010 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:53.995453 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:54.405100 [ 3598 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d1eea20f-c94b-4f26-bb1f-af47f7265f25::202503_1_194_49}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:54.715962 [ 3490 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:55.047947 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:55.716755 [ 3479 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:56.168178 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:56.717531 [ 3457 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:57.263730 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:57.718272 [ 3449 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:58.314445 [ 12293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:58.571466 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:20:58.719090 [ 3433 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:20:59.363521 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:20:59.719879 [ 3418 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:00.441501 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:00.720597 [ 3412 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:01.471922 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:01.721441 [ 3387 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:02.524040 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:02.722410 [ 3368 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:03.634916 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:03.723197 [ 3349 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:04.723926 [ 3371 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:04.727861 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:05.724586 [ 3318 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:05.763202 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:06.596409 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:21:06.725328 [ 3311 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:07.014472 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:07.726363 [ 3294 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:08.099975 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:08.727078 [ 3272 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:09.148873 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:09.727728 [ 3282 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:10.313698 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:10.728556 [ 3250 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:11.356287 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:11.729317 [ 3232 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:12.381556 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:12.730222 [ 3222 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:13.397114 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:13.731162 [ 3215 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:14.425508 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:14.731848 [ 3507 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:15.447155 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:15.732568 [ 3511 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:16.470502 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:16.733323 [ 3180 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:17.608086 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:17.734532 [ 3162 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:18.700037 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:18.735297 [ 3154 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:19.727698 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:19.735975 [ 3138 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:20.736707 [ 3121 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:20.838951 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:21.737426 [ 3113 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:21.948437 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:22.738376 [ 3100 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:23.073869 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:23.739234 [ 3091 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:24.157018 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:24.740331 [ 3082 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:25.185009 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:25.741222 [ 3057 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:26.210444 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:26.742058 [ 3032 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:27.305045 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:27.742739 [ 3022 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:28.332130 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:28.743564 [ 3009 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:29.492077 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:29.744306 [ 3488 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:30.580251 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:30.745139 [ 3472 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:31.690183 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:31.746207 [ 3459 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:32.724980 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:32.747018 [ 3448 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:33.747706 [ 3426 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:33.857597 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:34.748594 [ 3415 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:34.967224 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:35.749492 [ 3400 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:36.094662 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:36.750196 [ 3399 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:37.159242 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:37.750855 [ 3377 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:38.323256 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:38.751537 [ 3355 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:39.400085 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:39.752255 [ 3351 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:40.450852 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:40.753009 [ 3327 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:41.665040 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:41.753938 [ 3304 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:42.733256 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:42.755248 [ 3299 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:43.755996 [ 3291 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:43.922936 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:44.756721 [ 3313 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:45.151538 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:45.757502 [ 3252 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:46.273119 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:46.758524 [ 3244 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:47.308972 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:47.759289 [ 3230 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:48.350578 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:48.760044 [ 3216 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:49.529926 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:49.760800 [ 3519 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:50.559017 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:50.761443 [ 3509 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:51.594159 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:51.762287 [ 3180 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:52.708995 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:52.762932 [ 3177 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:53.763785 [ 3160 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:53.914167 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:54.764643 [ 3158 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:54.935981 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:55.765495 [ 3123 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:56.006975 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:56.766295 [ 3106 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:57.077207 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:57.767014 [ 3087 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:58.110692 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:58.767720 [ 3081 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:21:59.160660 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:21:59.768659 [ 3062 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:00.186794 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:00.769559 [ 3056 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:01.235821 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:01.770438 [ 3034 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:02.370457 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:02.771310 [ 3017 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:03.481008 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:03.771979 [ 3008 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:04.559430 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:04.772639 [ 3480 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:05.594580 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:05.773387 [ 3472 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:06.651856 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:06.774118 [ 3463 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:07.714240 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:07.774830 [ 3448 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:08.775612 [ 3433 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:08.806575 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:09.776396 [ 3414 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:09.950491 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:10.777012 [ 3412 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:11.084749 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:11.777686 [ 3388 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:12.252261 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:12.778506 [ 3369 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:13.465391 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:13.779274 [ 3359 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:14.595195 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:14.780109 [ 3354 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:15.710670 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:15.780908 [ 3371 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:16.781357 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:16.874734 [ 3318 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:17.875537 [ 3301 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:17.917207 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:18.876328 [ 3312 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:18.976887 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:19.877151 [ 3278 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:20.024082 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:20.878314 [ 3282 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:21.058372 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:21.879155 [ 3261 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:22.193670 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:22.880203 [ 3239 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:23.339279 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:23.881010 [ 3223 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:24.379608 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:24.882137 [ 3215 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:25.395642 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:25.882943 [ 3509 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:26.154895 [ 3610 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d1eea20f-c94b-4f26-bb1f-af47f7265f25::202503_1_206_61}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009656d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009133f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff77dff 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x0000000020113c7f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3a3572 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a0374 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:26.429005 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:26.883761 [ 3192 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:27.472983 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:27.884561 [ 3170 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:28.495926 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:28.885396 [ 3161 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:29.583493 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:29.886130 [ 3158 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:30.682073 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:30.886935 [ 3131 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:31.796219 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:31.887859 [ 3119 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:32.862445 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:32.888907 [ 3103 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:33.889704 [ 3102 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:33.913967 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:34.890643 [ 3082 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:35.027686 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:35.891508 [ 3063 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:36.162750 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:36.892399 [ 3042 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:37.231960 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:37.893338 [ 3029 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:38.281912 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:38.894224 [ 3011 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:39.375743 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:39.895017 [ 3494 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:40.424511 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:40.895946 [ 3484 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:41.522884 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:41.896814 [ 3451 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:42.571293 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:42.897630 [ 3456 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:43.604910 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:43.898570 [ 3441 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:44.808084 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:44.899345 [ 3429 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:45.844679 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:45.900234 [ 3404 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:46.882607 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:46.901114 [ 3392 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:47.902125 [ 3385 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:47.946699 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:48.902961 [ 3370 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:48.988286 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:49.903801 [ 3350 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:50.062571 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:50.904551 [ 3371 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:51.107526 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:51.905387 [ 3323 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:52.248337 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:52.906218 [ 3311 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:53.321411 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:53.906969 [ 3290 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:54.384113 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:54.907775 [ 3291 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:55.436732 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:55.908691 [ 3271 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:56.472849 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:56.909458 [ 3252 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:57.526257 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:57.910278 [ 3234 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:58.572708 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:58.911296 [ 3227 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:22:59.755163 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:22:59.912224 [ 3209 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:00.834017 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:00.913317 [ 3204 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:01.874384 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:01.914775 [ 3517 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:02.915703 [ 3195 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:03.035462 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:03.916589 [ 3189 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:04.050087 [ 3601 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d1eea20f-c94b-4f26-bb1f-af47f7265f25::202503_1_211_66}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009656d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009133f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff77dff 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x0000000020113c7f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3a3572 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a0374 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:04.068100 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:04.917429 [ 3168 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:05.111688 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:05.918223 [ 3147 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:06.138452 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:06.919053 [ 3135 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:07.209020 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:07.919959 [ 3120 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:08.239431 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:08.920812 [ 3110 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:09.290671 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:09.921662 [ 3097 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:10.439566 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:10.989379 [ 3082 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:11.530082 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:11.990569 [ 3070 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:12.658699 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:12.991379 [ 3051 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:13.706517 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:13.992161 [ 3032 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:14.808120 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:14.992990 [ 3027 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:15.862354 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:15.994153 [ 3498 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:16.978396 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:16.995353 [ 3483 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:17.996157 [ 3466 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:18.107350 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:18.997137 [ 3452 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:19.325255 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:19.998223 [ 3444 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:20.416316 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:20.998922 [ 3430 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:21.494146 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:21.999734 [ 3406 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:22.603750 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:23.000636 [ 3390 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:23.657954 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:24.001425 [ 3380 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:24.693750 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:25.002247 [ 3368 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:25.727833 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:26.003031 [ 3340 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:26.786627 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:26.957426 [ 3600 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d1eea20f-c94b-4f26-bb1f-af47f7265f25::202503_1_214_69}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009656d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009133f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff77dff 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x0000000020113c7f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3a3572 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a0374 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:27.004073 [ 3342 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:27.911188 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:28.004919 [ 3328 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:28.984382 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:29.005690 [ 3297 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:30.004577 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:30.006924 [ 3293 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:31.007826 [ 3276 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:31.087142 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:32.008728 [ 3263 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:32.152981 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:33.009532 [ 3261 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:33.206055 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:34.010661 [ 3243 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:34.351391 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:35.011411 [ 3229 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:35.418549 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:35.527145 [ 3609 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ccd9e83a-9834-41dc-89e2-4a5d7824dd6d::202503_1_181_38}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:36.012175 [ 3212 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:36.145135 [ 3600 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ccd9e83a-9834-41dc-89e2-4a5d7824dd6d::202503_1_181_38}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:36.529511 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:37.012981 [ 3510 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:37.666268 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:38.013883 [ 3198 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:38.713871 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:39.014621 [ 3189 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:39.750174 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:40.015356 [ 3168 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:40.792689 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:41.016101 [ 3159 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:41.849636 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:42.016978 [ 3140 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:42.910730 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:43.017846 [ 3136 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:43.998562 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:44.018524 [ 3118 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:45.019429 [ 3103 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:45.126482 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:46.020281 [ 3090 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:46.237029 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:47.021084 [ 3080 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:47.367977 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:48.022103 [ 3061 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:48.386225 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:49.022837 [ 3034 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:49.417656 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:50.023520 [ 3028 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:50.579247 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:51.024374 [ 3500 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:51.678087 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:52.025137 [ 3505 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:52.714764 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:53.026201 [ 3479 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:53.757499 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:54.026963 [ 3459 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:54.803250 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:55.027773 [ 3462 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:55.843769 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:56.028501 [ 3436 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:56.896723 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:57.029169 [ 3423 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:57.131232 [ 3597 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d1eea20f-c94b-4f26-bb1f-af47f7265f25::202503_1_218_73}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009656d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009133f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff77dff 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x0000000020113c7f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3a3572 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a0374 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:58.030061 [ 3424 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:58.043952 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:23:59.030790 [ 3386 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:23:59.136879 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:00.031840 [ 3368 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:00.175270 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:01.032759 [ 3341 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:01.207152 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:02.033613 [ 3343 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:02.251190 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:03.034380 [ 3326 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:03.303823 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:04.035226 [ 3321 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:04.338892 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:05.036067 [ 3300 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:05.453697 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:06.036819 [ 3272 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:06.485560 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:07.037602 [ 3269 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:07.592933 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:08.038587 [ 3256 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:08.713141 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:09.039317 [ 3241 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:09.815594 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:10.040033 [ 3222 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:10.953879 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:11.040939 [ 3209 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:11.972116 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:12.041823 [ 3215 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:13.042527 [ 3517 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:13.074009 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:14.043228 [ 3193 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:14.100336 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:15.043956 [ 3189 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:15.132986 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:16.044760 [ 3165 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:16.247364 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:17.045542 [ 3157 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:17.276561 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:18.046418 [ 3142 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:18.317614 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:19.047259 [ 3126 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:19.363220 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:20.048522 [ 3106 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:20.500486 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:21.049366 [ 3088 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:21.532197 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:22.050179 [ 3079 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:22.552127 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:23.051092 [ 3074 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:23.588100 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:24.052015 [ 3053 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:24.612490 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:25.052977 [ 3050 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:25.642652 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:26.054084 [ 3024 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:26.723814 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:27.054870 [ 3021 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:27.844229 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:28.055666 [ 3496 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:28.871620 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:29.056577 [ 3482 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:29.964603 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:30.057402 [ 3465 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:31.036027 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:31.058687 [ 3450 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:32.059566 [ 3439 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:32.065359 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:33.060404 [ 3425 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:33.166007 [ 19199 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x00000000125b52aa 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031595849 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000031593ecb 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000315947ca 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x00000000337446ce 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000033745810 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000003abdbee8 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000003abb0518 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000003ab93025 12. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::run() @ 0x000000003abe9e51 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:24:34.061221 [ 3400 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:35.062267 [ 3399 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:36.063097 [ 3369 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:37.063837 [ 3353 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:37.169137 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:24:38.064541 [ 3346 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:39.065421 [ 3334 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:40.066318 [ 3305 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:41.067045 [ 3314 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:42.067803 [ 3286 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:43.068581 [ 3279 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:43.105336 [ 3595 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d1eea20f-c94b-4f26-bb1f-af47f7265f25::202503_1_224_79}: 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000002009656d 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000002009133f 5. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:129: CurrentMemoryTracker::injectFault() @ 0x000000001ff77dff 6. ./build_docker/./src/Common/ThreadFuzzer.cpp:270: DB::ThreadFuzzer::maybeInjectMemoryLimitException() @ 0x0000000020113c7f 7. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:151: DB::MergePlainMergeTreeTask::finish() @ 0x000000003a3a3572 8. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a0374 9. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 10. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 15. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 17. ? @ 0x00007f038ce47ac3 18. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:44.069331 [ 3261 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:45.070417 [ 3232 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:46.071290 [ 3222 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:47.071957 [ 3213 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:48.072827 [ 3379 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:49.074069 [ 3198 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:50.074835 [ 3176 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:51.075833 [ 3173 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:52.076813 [ 3159 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:53.078212 [ 3145 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:54.079013 [ 3131 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:55.079791 [ 3111 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:56.080878 [ 3107 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:57.082101 [ 3095 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:58.082949 [ 3082 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:24:59.083807 [ 3060 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:00.084764 [ 3044 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:01.085445 [ 3029 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:02.086302 [ 3020 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:03.086975 [ 3495 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:04.087749 [ 3480 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:05.088631 [ 3478 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:06.089498 [ 3474 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:07.090965 [ 3447 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:08.091784 [ 3431 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:09.092614 [ 3422 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:10.093385 [ 3395 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:11.094233 [ 3396 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:12.094996 [ 3382 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:13.095849 [ 3367 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:14.096687 [ 3352 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:15.097482 [ 3342 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:16.098793 [ 3329 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:17.099636 [ 3321 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:18.100509 [ 3300 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:19.101285 [ 3283 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:20.102373 [ 3266 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:21.103311 [ 3258 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:22.104179 [ 3255 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:23.104946 [ 3230 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:24.106038 [ 3206 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:25.106795 [ 3204 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:26.107634 [ 3514 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:27.108428 [ 3197 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:28.109335 [ 3176 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:29.174587 [ 3175 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:30.175424 [ 3161 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:31.176209 [ 3142 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:32.177059 [ 3124 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:33.178028 [ 3115 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:34.178791 [ 3104 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:35.179483 [ 3092 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:36.180209 [ 3076 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:37.181145 [ 3055 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:38.182135 [ 3043 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:39.182979 [ 3017 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:40.183837 [ 3498 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:41.184808 [ 3483 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:42.185612 [ 3486 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:43.186655 [ 3479 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:44.187427 [ 3458 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:45.188187 [ 3427 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:46.188944 [ 3416 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:47.189856 [ 3421 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:48.190726 [ 3398 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:49.191412 [ 3386 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:50.192190 [ 3359 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:51.192888 [ 3378 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:52.194105 [ 3339 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:53.194927 [ 3306 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:54.195733 [ 3314 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:55.196623 [ 3284 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:56.197426 [ 3276 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:56.556322 [ 3601 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {0f4221a3-ac36-4096-997d-800f51b611e3::202503_1_35_7}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:57.198291 [ 3282 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:58.199071 [ 3247 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:25:59.199933 [ 3229 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:00.200727 [ 3206 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:01.201487 [ 3519 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:02.202325 [ 3504 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:03.203200 [ 3182 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:04.203932 [ 3166 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:05.204782 [ 3152 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:06.205550 [ 3146 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:07.206415 [ 3136 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:08.207196 [ 3105 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:09.207969 [ 3094 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:10.208803 [ 3073 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:11.209642 [ 3067 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:12.211130 [ 3052 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:13.212047 [ 3048 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:14.212923 [ 3029 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:15.213660 [ 3500 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:16.214484 [ 3494 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:17.215355 [ 3484 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:18.216258 [ 3469 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:19.217079 [ 3454 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:20.218149 [ 3447 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:21.218819 [ 3443 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:22.219698 [ 3419 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:23.220586 [ 3395 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:24.221386 [ 3386 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:25.266793 [ 3363 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:26.267695 [ 3378 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:27.268506 [ 3342 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:28.269319 [ 3326 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:28.991470 [ 3603 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c38c8cc9-27b1-4991-900a-4bc8e9c3b6da::202503_1_229_46}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:29.270071 [ 3301 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:29.649614 [ 3605 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7b93f28a-4c9d-4e36-add9-0e92a5ccdc5c::202503_1_252_84}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:29.755637 [ 3596 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c38c8cc9-27b1-4991-900a-4bc8e9c3b6da::202503_1_229_46}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f038ce47ac3 29. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:30.271392 [ 3291 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:31.272107 [ 3266 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:32.272858 [ 3263 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:33.273903 [ 3310 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:34.274769 [ 3241 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:35.275570 [ 3223 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:36.276227 [ 3214 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:37.277054 [ 3514 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:38.277894 [ 3185 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:39.278712 [ 3178 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:40.279537 [ 3156 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:41.280378 [ 3150 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:42.281246 [ 3142 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:43.282820 [ 3134 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:44.283584 [ 3106 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:45.284303 [ 3088 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:46.285272 [ 3092 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:47.286312 [ 3069 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:48.287215 [ 3060 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:49.288126 [ 3047 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:50.288937 [ 3034 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:51.289698 [ 3025 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:52.290918 [ 3018 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:53.291647 [ 3493 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:54.292586 [ 3473 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:55.293404 [ 3455 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:56.294479 [ 3454 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:57.295221 [ 3439 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:58.296017 [ 3425 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:26:59.296750 [ 3407 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:00.297493 [ 3396 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:01.298289 [ 3380 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:02.299103 [ 3363 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:03.299873 [ 3340 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:04.300720 [ 3346 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:05.301615 [ 3324 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:06.302819 [ 3306 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:07.303724 [ 3299 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:08.304421 [ 3283 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:09.305079 [ 3265 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:10.392454 [ 3253 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:11.393202 [ 3239 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:12.394269 [ 3228 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:13.395102 [ 3217 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:14.395928 [ 3517 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:15.396993 [ 3191 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:16.398110 [ 3188 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:17.398960 [ 3165 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:18.399875 [ 3148 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:19.400712 [ 3138 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:20.401662 [ 3126 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:21.402838 [ 3106 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:22.403748 [ 3099 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:23.404559 [ 3081 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:24.405459 [ 3059 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:25.406343 [ 3041 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:26.407232 [ 3045 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:27.408088 [ 3020 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:28.408982 [ 3501 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:29.410069 [ 3481 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:30.410828 [ 3461 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:31.426224 [ 3456 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:32.426934 [ 3443 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:33.427647 [ 3419 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:34.428342 [ 3395 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:35.429184 [ 3391 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:36.430118 [ 3375 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:37.431011 [ 3364 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:38.431791 [ 3340 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:39.432713 [ 3337 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:40.433612 [ 3325 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:41.434718 [ 3322 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:42.435568 [ 3319 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:43.436365 [ 3275 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:44.437178 [ 3265 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:45.439112 [ 3261 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:46.439948 [ 3233 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:47.440820 [ 3228 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:48.441972 [ 3202 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:49.442692 [ 3509 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:50.443614 [ 3194 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:51.444428 [ 3186 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:52.445214 [ 3162 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:53.446327 [ 3159 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:54.447220 [ 3144 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:55.448011 [ 3123 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:56.448906 [ 3106 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:57.449953 [ 3098 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:58.450855 [ 3081 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:27:59.452042 [ 3070 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:00.452898 [ 3066 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:01.453899 [ 3041 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:02.454769 [ 3038 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:03.455581 [ 3015 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:04.456427 [ 3492 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:05.457264 [ 3482 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:06.458262 [ 3465 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:07.459162 [ 3464 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:08.459919 [ 3441 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:09.460839 [ 3429 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:10.461930 [ 3405 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:11.462779 [ 3412 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:12.463548 [ 3391 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:13.464304 [ 3370 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:14.465098 [ 3366 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:15.466062 [ 3354 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:16.466844 [ 3327 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:17.467626 [ 3305 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:18.468419 [ 3298 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:19.469200 [ 3312 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:20.470098 [ 3266 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:21.471039 [ 3262 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:22.472065 [ 3261 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:23.472948 [ 3232 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:24.473704 [ 3219 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:25.500286 [ 3215 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:26.501176 [ 3507 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:27.502091 [ 3193 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:28.502830 [ 3172 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:29.503591 [ 3166 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:30.504390 [ 3152 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:31.505288 [ 3144 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:32.539696 [ 3133 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:33.540418 [ 3118 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:34.541190 [ 3107 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:35.542083 [ 3096 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:36.542892 [ 3085 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:37.543642 [ 3074 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:38.544391 [ 3066 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:39.545149 [ 3034 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:40.546245 [ 3023 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:41.547033 [ 3011 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:42.547774 [ 3490 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:43.548532 [ 3473 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:44.549334 [ 3459 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:45.550348 [ 3464 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:46.551142 [ 3445 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:47.552082 [ 3430 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:48.552863 [ 3418 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:49.553704 [ 3398 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:50.554814 [ 3386 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:51.555620 [ 3376 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:52.556434 [ 3366 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:53.557268 [ 3347 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:54.558044 [ 3337 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:55.558887 [ 3304 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:56.559568 [ 3314 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:57.560321 [ 3289 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:58.561155 [ 3278 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:28:59.562246 [ 3268 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:00.563041 [ 3252 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:01.563793 [ 3247 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:02.564586 [ 3238 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:03.565322 [ 3218 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:04.566119 [ 3202 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:05.566990 [ 3509 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:06.567769 [ 3193 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:07.568547 [ 3188 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:08.569231 [ 3165 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:09.570092 [ 3152 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:10.570960 [ 3128 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:11.571845 [ 3117 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:12.572835 [ 3108 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:13.573663 [ 3096 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:14.574712 [ 3085 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:15.575628 [ 3071 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:16.576444 [ 3059 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:17.577225 [ 3056 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:17.596987 [ 3830 ] {3837bb61-8ed5-44d4-ae8f-7aae088fd5b3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59402) (comment: 02724_delay_mutations.sh) (in query: DROP DATABASE IF EXISTS test_9h9yztr4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:29:17.599863 [ 3830 ] {3837bb61-8ed5-44d4-ae8f-7aae088fd5b3} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:17.622222 [ 19199 ] {779295ca-4d38-49ae-b32d-e6a639bb25cf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59406) (comment: 02724_delay_mutations.sh) (in query: DROP DATABASE IF EXISTS test_9h9yztr4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:29:17.626207 [ 19199 ] {779295ca-4d38-49ae-b32d-e6a639bb25cf} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:17.735807 [ 3830 ] {3e7dcdcb-fb75-4344-aa86-d490f4a025a6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:59418) (comment: 02724_delay_mutations.sh) (in query: DROP DATABASE IF EXISTS test_9h9yztr4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 2025.03.31 19:29:17.738737 [ 3830 ] {3e7dcdcb-fb75-4344-aa86-d490f4a025a6} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x00000000083cda64 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x000000003399b2da 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>>>&) @ 0x0000000034931cf7 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000034923a6d 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000034920be1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::execute() @ 0x0000000034920173 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 11. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 12. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 17. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 18. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 19. ? @ 0x00007f038ce47ac3 20. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:18.578138 [ 3300 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:19.578961 [ 3280 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:20.579809 [ 3511 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:21.580610 [ 3417 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:22.552533 [ 3717 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:29:22.581228 [ 3348 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:23.581874 [ 3178 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:29:24.342194 [ 5939 ] {5f95680e-e057-4594-9d00-3de966703286} StorageBuffer (test_1.part_01278_2): Destination table test_1.null_01278 doesn't exist. Block of data is discarded. 2025.03.31 19:29:24.342312 [ 5937 ] {5f95680e-e057-4594-9d00-3de966703286} StorageBuffer (test_1.part_01278_1): Destination table test_1.null_01278 doesn't exist. Block of data is discarded. 2025.03.31 19:29:24.342373 [ 5928 ] {5f95680e-e057-4594-9d00-3de966703286} StorageBuffer (test_1.part_01278_3): Destination table test_1.null_01278 doesn't exist. Block of data is discarded. 2025.03.31 19:29:24.343439 [ 5918 ] {5f95680e-e057-4594-9d00-3de966703286} StorageBuffer (test_1.part_01278_4): Destination table test_1.null_01278 doesn't exist. Block of data is discarded. 2025.03.31 19:29:24.346754 [ 5933 ] {5f95680e-e057-4594-9d00-3de966703286} StorageBuffer (test_1.part_01278_5): Destination table test_1.null_01278 doesn't exist. Block of data is discarded. 2025.03.31 19:29:24.346775 [ 5929 ] {5f95680e-e057-4594-9d00-3de966703286} StorageBuffer (test_1.part_01278_6): Destination table test_1.null_01278 doesn't exist. Block of data is discarded. 2025.03.31 19:29:24.348098 [ 5919 ] {5f95680e-e057-4594-9d00-3de966703286} StorageBuffer (test_1.part_01278_7): Destination table test_1.null_01278 doesn't exist. Block of data is discarded. 2025.03.31 19:29:24.349922 [ 5905 ] {5f95680e-e057-4594-9d00-3de966703286} StorageBuffer (test_1.part_01278_8): Destination table test_1.null_01278 doesn't exist. Block of data is discarded. 2025.03.31 19:29:24.350739 [ 5917 ] {5f95680e-e057-4594-9d00-3de966703286} StorageBuffer (test_1.part_01278_9): Destination table test_1.null_01278 doesn't exist. Block of data is discarded. 2025.03.31 19:29:24.584970 [ 3114 ] {} test_gsziu8cx.replicated_mutation_table (090c03d6-5eac-4b9c-8a7d-e55945964e3a): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01414_mutations_and_errors_zookeeper_test_gsziu8cx/mutation_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x00000000083ba10a 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:5636: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x00000000386cd0d2 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:3960: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000003888efe1 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000038a8a9ff 7. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x0000000031997692 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000319a29b3 9. ./build_docker/./src/Core/BackgroundSchedulePool.cpp:0: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000319a464f 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f038ce47ac3 13. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:30:25.164994 [ 33094 ] {fb348c62-6433-4138-b552-fc2e1a97c985} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.254240543 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:46052) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322bdecd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322bbf48 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x00000000350103dc 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae5fc4e 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f50a 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*) @ 0x000000003ae9f89d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 11. ? @ 0x00007f038ce47ac3 12. ? @ 0x00007f038ced9850 2025.03.31 19:30:25.167556 [ 33094 ] {fb348c62-6433-4138-b552-fc2e1a97c985} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.254240543 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000322bdecd 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x00000000322bbf48 5. ./build_docker/./src/Interpreters/ProcessList.cpp:482: DB::QueryStatus::checkTimeLimit() @ 0x00000000350103dc 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000003ae5fc4e 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f50a 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*) @ 0x000000003ae9f89d 9. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 11. ? @ 0x00007f038ce47ac3 12. ? @ 0x00007f038ced9850 2025.03.31 19:30:26.678244 [ 19199 ] {9cb354e0-5d9b-4d5f-863b-f9351e53b679} 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.10457.altinitytest (altinity build)) (from [::1]:54618) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000329a9e92 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x00000000329a97a8 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x00000000329a8704 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348823e2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 2025.03.31 19:30:26.681254 [ 19199 ] {9cb354e0-5d9b-4d5f-863b-f9351e53b679} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x00000000329a9e92 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x00000000329a97a8 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x00000000329a8704 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000348823e2 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::execute() @ 0x00000000348e31e6 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x00000000358a2575 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&)>) @ 0x00000000358afdd7 10. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000003a9e7911 11. ./build_docker/./src/Server/HTTPHandler.cpp:706: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000003a9f3d28 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000003ac16181 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x00000000405ea420 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: Poco::Net::TCPServerDispatcher::run() @ 0x00000000405eb360 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:0: Poco::PooledThread::run() @ 0x00000000404cd0f5 16. ./build_docker/./base/poco/Foundation/src/Thread.cpp:46: Poco::(anonymous namespace)::RunnableHolder::run() @ 0x00000000404c9ace 17. ./base/poco/Foundation/include/Poco/AutoPtr.h:205: Poco::ThreadImpl::runnableEntry(void*) @ 0x00000000404c6991 18. ? @ 0x00007f038ce47ac3 19. ? @ 0x00007f038ced9850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:30:38.767615 [ 2850 ] {} Application: Closed all listening sockets. Waiting for 8 outstanding connections. 2025.03.31 19:30:43.673740 [ 2850 ] {} Application: Closed connections. But 8 remain. Tip: To increase wait time add to config: 60 2025.03.31 19:30:43.674125 [ 2850 ] {} Application: Will shutdown forcefully. 2025.03.31 19:30:46.002584 [ 33155 ] {} Context: Server was built with memory sanitizer. It will work slowly. 2025.03.31 19:30:46.025163 [ 33155 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.03.31 19:30:46.029421 [ 33155 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.03.31 19:30:46.031073 [ 33155 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.03.31 19:30:56.670880 [ 33155 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.03.31 19:30:56.679425 [ 33155 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.03.31 19:30:56.679511 [ 33155 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.03.31 19:30:56.730894 [ 33796 ] {} RaftInstance: Election timeout, initiate leader election 2025.03.31 19:30:58.214331 [ 33938 ] {} system.asynchronous_metric_log (7b93f28a-4c9d-4e36-add9-0e92a5ccdc5c): Removing temporary directory /var/lib/clickhouse/store/7b9/7b93f28a-4c9d-4e36-add9-0e92a5ccdc5c/tmp_merge_202503_1_287_119/ 2025.03.31 19:31:00.100516 [ 33155 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.03.31 19:31:00.412541 [ 33155 ] {} loadMetadata: Removing temporary file /var/lib/clickhouse/metadata/test.sql.tmp 2025.03.31 19:31:00.697077 [ 33155 ] {} TablesLoader: Tables test_e21kt9ba.invalidate depend on test_e21kt9ba.dict_invalidate, but seems like that does not exist. Will ignore it and try to load existing tables 2025.03.31 19:31:01.286468 [ 33970 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=731, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202ded94 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202cd269 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202cef14 6. ./src/Common/ThreadPool.h:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x000000003397a239 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:132: DB::DDLWorker::startup() @ 0x0000000033929a1d 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&) @ 0x0000000032a8df1f 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000002070bcc6 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002070d6e0 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 14. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 16. ? @ 0x00007f6112aa1ac3 17. ? @ 0x00007f6112b33850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:31:01.658428 [ 33164 ] {9de062cf-6b3a-4ad2-8da4-9ccd30fafecb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10457.altinitytest (altinity build)) (from [::1]:47698) (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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f6112aa1ac3 13. ? @ 0x00007f6112b33850 2025.03.31 19:31:01.660321 [ 33164 ] {9de062cf-6b3a-4ad2-8da4-9ccd30fafecb} 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::spawnThreads() @ 0x000000003ae6390c 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000003ae5f8b5 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000003ae5f408 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*) @ 0x000000003ae9f89d 10. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 12. ? @ 0x00007f6112aa1ac3 13. ? @ 0x00007f6112b33850 2025.03.31 19:31:15.200194 [ 33938 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:31:15.736921 [ 33836 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {8c2d7c1f-a424-404f-ac7d-e150141efc8a::202503_1_159_35}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 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&&) @ 0x0000000039bf1143 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000039be6182 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x0000000039be55f9 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) @ 0x0000000039c69268 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&&) @ 0x000000003997b917 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 @ 0x0000000039973c50 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) @ 0x0000000039cf5524 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&) @ 0x0000000039cffcb9 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) @ 0x0000000039cfbf26 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x0000000039612b44 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000003960587d 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000003961d680 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x0000000039632740 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000003a3a039d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:286: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000003968dede 21. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:0: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000003968fca8 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000039696fbf 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000202d2173 24. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000202e47a6 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x00000000202e455f 26. ./base/base/../base/wide_integer_impl.h:817: ThreadPoolImpl::ThreadFromThreadPool::worker() @ 0x00000000202cafdd 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x00000000202dd524 28. ? @ 0x00007f6112aa1ac3 29. ? @ 0x00007f6112b33850 (version 24.8.14.10457.altinitytest (altinity build)) 2025.03.31 19:31:17.390603 [ 33938 ] {} PushingToViews: Failed to push block to view test_1.slow_log (1201d287-1452-40cb-bcf4-f6073b58f321), Unknown table expression identifier 'test_1.expected_times' in scope SELECT * FROM (SELECT extract(query, '/\\*\\s*QUERY_GROUP_ID:(.*?)\\s*\\*/') AS QUERY_GROUP_ID, * FROM system.query_log WHERE (type != 1) AND (event_date >= yesterday())) AS ql INNER JOIN test_1.expected_times USING (QUERY_GROUP_ID) WHERE query_duration_ms > max_query_duration_ms 2025.03.31 19:31:21.076319 [ 33155 ] {} virtual void DB::StorageBuffer::flushAndPrepareForShutdown(): 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) @ 0x00000000403aa0e9 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000002002cdf3 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x0000000008378b9d 3. ./src/Common/Exception.h:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x00000000202e51d4 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x00000000202d5709 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000202d4f8a 6. ./src/Common/threadPoolCallbackRunner.h:0: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority) @ 0x00000000303e9a7d 7. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::flushAllBuffers(bool) @ 0x0000000038dbe04c 8. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::StorageBuffer::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000038dbd5e8 9. ./contrib/llvm-project/libcxx/include/vector:438: DB::StorageBuffer::flushAndPrepareForShutdown() @ 0x0000000038dbcdf3 10. ./src/Storages/IStorage.h:594: DB::DatabaseWithOwnTablesBase::shutdown() @ 0x0000000032ae6654 11. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:184: DB::DatabaseOnDisk::shutdown() @ 0x000000003293dd0a 12. ./contrib/llvm-project/libcxx/include/__tree:189: DB::DatabaseCatalog::shutdownImpl() @ 0x000000003398ab6f 13. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:867: DB::DatabaseCatalog::shutdown() @ 0x00000000339a2daf 14. ./build_docker/./src/Interpreters/Context.cpp:624: DB::ContextSharedPart::shutdown() @ 0x00000000337bfc20 15. ./build_docker/./src/Interpreters/Context.cpp:4783: DB::Context::shutdown() @ 0x0000000033791d9f 16. ./build_docker/./programs/server/Server.cpp:936: DB::Server::main(std::vector> const&)::$_2::operator()() const @ 0x0000000020633a96 17. ./base/base/../base/scope_guard.h:0: DB::Server::main(std::vector> const&) @ 0x00000000205ef260 18. ./build_docker/./base/poco/Util/src/Application.cpp:0: Poco::Util::Application::run() @ 0x0000000040664a7f 19. ./build_docker/./programs/server/Server.cpp:397: DB::Server::run() @ 0x00000000205b1a6b 20. ./build_docker/./base/poco/Util/src/ServerApplication.cpp:132: Poco::Util::ServerApplication::run(int, char**) @ 0x00000000406abd60 21. ./build_docker/./programs/server/Server.cpp:0: mainEntryClickHouseServer(int, char**) @ 0x00000000205aa549 22. ./build_docker/./programs/main.cpp:0: main @ 0x0000000008365c4a 23. ? @ 0x00007f6112a36d90 24. ? @ 0x00007f6112a36e40 25. _start @ 0x00000000082d902e (version 24.8.14.10457.altinitytest (altinity build))